- A - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- A - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- A - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- A - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- AB_MAGIC - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- abort() - Method in class org.apache.cassandra.auth.CassandraLoginModule
-
This method is called if the LoginContext's overall authentication failed.
- abort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- abort() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- abort() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- abort() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- abort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- abort() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
Abort this task.
- abort() - Method in class org.apache.cassandra.streaming.StreamTask
-
Abort the task.
- abort() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- abort(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
-
- abort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
rollback any effects of this transaction object graph; delegates first to doCleanup, then to doAbort
- abort() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- abortEarly() - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
-
- abortEarly() - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
-
- abortOrDie(SSTableMultiWriter) - Static method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- abortRunnables(List<Memtable.FlushRunnable>, Throwable) - Method in class org.apache.cassandra.db.Memtable
-
- abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- abs(long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- AbstractAllocator - Class in org.apache.cassandra.utils.memory
-
- AbstractAllocator() - Constructor for class org.apache.cassandra.utils.memory.AbstractAllocator
-
- AbstractAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
-
- AbstractAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
-
- 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(CFMetaData, DecoratedKey) - Constructor for class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- AbstractBTreePartition.Holder - Class in org.apache.cassandra.db.partitions
-
- AbstractBTreePartition.SlicesIterator - Class in org.apache.cassandra.db.partitions
-
- AbstractBufferClusteringPrefix - Class in org.apache.cassandra.db
-
- AbstractBufferClusteringPrefix(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.AbstractBufferClusteringPrefix
-
- AbstractCell - Class in org.apache.cassandra.db.rows
-
Base abstract class for Cell
implementations.
- AbstractCell(ColumnDefinition) - Constructor for class org.apache.cassandra.db.rows.AbstractCell
-
- AbstractClusteringIndexFilter - Class in org.apache.cassandra.db.filter
-
- AbstractClusteringIndexFilter(boolean) - Constructor for class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
-
- AbstractClusteringPrefix - Class in org.apache.cassandra.db
-
- AbstractClusteringPrefix() - Constructor for class org.apache.cassandra.db.AbstractClusteringPrefix
-
- 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
-
- AbstractCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
Pluggable compaction strategy determines how SSTables get merged.
- AbstractCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- AbstractCompactionStrategy.ScannerList - Class in org.apache.cassandra.db.compaction
-
- AbstractCompactionTask - Class in org.apache.cassandra.db.compaction
-
- AbstractCompactionTask(ColumnFamilyStore, LifecycleTransaction) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- AbstractCompositeType - Class in org.apache.cassandra.db.marshal
-
A class avoiding class duplication between CompositeType and
DynamicCompositeType.
- AbstractCompositeType() - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- AbstractCompositeType.ParsedComparator - Interface in org.apache.cassandra.db.marshal
-
- AbstractEndpointSnitch - Class in org.apache.cassandra.locator
-
- AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- AbstractFunction - Class in org.apache.cassandra.cql3.functions
-
Base class for our native/hardcoded functions.
- AbstractFunction(FunctionName, List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
-
- AbstractIterator<T> - Class in org.apache.cassandra.index.sasi.utils
-
- AbstractIterator() - Constructor for class org.apache.cassandra.index.sasi.utils.AbstractIterator
-
Constructor for use by subclasses.
- AbstractIterator<V> - Class in org.apache.cassandra.utils
-
- AbstractIterator() - Constructor for class org.apache.cassandra.utils.AbstractIterator
-
- AbstractIterator.State - Enum in org.apache.cassandra.index.sasi.utils
-
- AbstractJmxClient - Class in org.apache.cassandra.tools
-
- AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
-
- AbstractLocalAwareExecutorService - Class in org.apache.cassandra.concurrent
-
- AbstractLocalAwareExecutorService() - Constructor for class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- AbstractMarker - Class in org.apache.cassandra.cql3
-
A single bind marker.
- AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
-
- AbstractMarker.INRaw - Class in org.apache.cassandra.cql3
-
A raw placeholder for multiple values of the same type for a single column.
- AbstractMarker.MultiColumnRaw - Class in org.apache.cassandra.cql3
-
A MultiColumnRaw version of AbstractMarker.Raw
- AbstractMarker.Raw - Class in org.apache.cassandra.cql3
-
A parsed, but non prepared, bind marker.
- AbstractNetworkTopologySnitch - Class in org.apache.cassandra.locator
-
An endpoint snitch tells Cassandra information about network topology that it can use to route
requests more efficiently.
- AbstractNetworkTopologySnitch() - Constructor for class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
- AbstractPaxosCallback<T> - Class in org.apache.cassandra.service.paxos
-
- AbstractPaxosCallback(int, ConsistencyLevel, long) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- AbstractRangeTombstoneMarker<B extends ClusteringBoundOrBoundary> - Class in org.apache.cassandra.db.rows
-
- AbstractRangeTombstoneMarker(B) - Constructor for class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- AbstractReadCommandBuilder - Class in org.apache.cassandra.db
-
- AbstractReadCommandBuilder.PartitionRangeBuilder - Class in org.apache.cassandra.db
-
- AbstractReadCommandBuilder.SinglePartitionBuilder - Class in org.apache.cassandra.db
-
- AbstractReadCommandBuilder.SinglePartitionSliceBuilder - Class in org.apache.cassandra.db
-
- AbstractReaderFileProxy - Class in org.apache.cassandra.io.util
-
- AbstractReaderFileProxy(ChannelProxy, long) - Constructor for class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- AbstractReadExecutor - Class in org.apache.cassandra.service
-
Sends a read request to the replicas needed to satisfy a given ConsistencyLevel.
- AbstractReadExecutor.NeverSpeculatingReadExecutor - Class in org.apache.cassandra.service
-
- 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
-
- AbstractReplicationStrategy.ReplicaCache<K,V> - Class in org.apache.cassandra.locator
-
- AbstractRow - Class in org.apache.cassandra.db.rows
-
Base abstract class for Row
implementations.
- AbstractRow() - Constructor for class org.apache.cassandra.db.rows.AbstractRow
-
- AbstractSecureIntializer(Server, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.Server.AbstractSecureIntializer
-
- AbstractSignal() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
-
- AbstractSSTableIterator - Class in org.apache.cassandra.db.columniterator
-
- AbstractSSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- AbstractSSTableIterator.IndexState - Class in org.apache.cassandra.db.columniterator
-
- AbstractSSTableIterator.Reader - Class in org.apache.cassandra.db.columniterator
-
- AbstractTextSerializer - Class in org.apache.cassandra.serializers
-
- AbstractTextSerializer(Charset) - Constructor for class org.apache.cassandra.serializers.AbstractTextSerializer
-
- AbstractTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder() - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- AbstractTokenTreeBuilder.InteriorNode - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder.Leaf - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder.Leaf.LeafEntry - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder.LevelIterator - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTokenTreeBuilder.Node - Class in org.apache.cassandra.index.sasi.disk
-
- AbstractTransactional() - Constructor for class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- AbstractType<T> - Class in org.apache.cassandra.db.marshal
-
Specifies a Comparator for a specific type of ByteBuffer.
- AbstractType(AbstractType.ComparisonType) - Constructor for class org.apache.cassandra.db.marshal.AbstractType
-
- AbstractType.ComparisonType - Enum in org.apache.cassandra.db.marshal
-
- AbstractUnfilteredPartitionIterator - Class in org.apache.cassandra.db.partitions
-
- AbstractUnfilteredPartitionIterator() - Constructor for class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
-
- AbstractUnfilteredRowIterator - Class in org.apache.cassandra.db.rows
-
- AbstractUnfilteredRowIterator(CFMetaData, DecoratedKey, DeletionTime, PartitionColumns, Row, boolean, EncodingStats) - Constructor for class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- AbstractWriteResponseHandler<T> - Class in org.apache.cassandra.service
-
- AbstractWriteResponseHandler(Keyspace, Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- accept(A, B, C) - Method in interface org.apache.cassandra.db.SystemKeyspace.TriFunction
-
- acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
-
- acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- accepts(OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.Memtable
-
- Accumulator<E> - Class in org.apache.cassandra.utils.concurrent
-
A simple append-only collection supporting an unbounded number of concurrent readers/writers,
but a bounded number of items.
- Accumulator(int) - Constructor for class org.apache.cassandra.utils.concurrent.Accumulator
-
- ackCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- ackMutation() - Method in class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
-
- acquire(int) - Method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
-
- acquire(double) - Method in class org.apache.cassandra.utils.TestRateLimiter
-
Acquires a single unit at the given rate.
- acquireLockFor(int) - Static method in class org.apache.cassandra.db.view.ViewManager
-
- acquireReference() - Method in class org.apache.cassandra.tracing.TraceState
-
- activate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to initialize and start the daemon in one shot.
- activeDeletion() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- ActiveRepairService - Class in org.apache.cassandra.service
-
ActiveRepairService is the starting point for manual "active" repairs.
- ActiveRepairService(IFailureDetector, Gossiper) - Constructor for class org.apache.cassandra.service.ActiveRepairService
-
- ActiveRepairService.ParentRepairSession - Class in org.apache.cassandra.service
-
We keep a ParentRepairSession around for the duration of the entire repair, for example, on a 256 token vnode rf=3 cluster
we would have 768 RepairSession but only one ParentRepairSession.
- ActiveRepairService.Status - Enum in org.apache.cassandra.service
-
- activeStreamsOutbound - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- activeTasks - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of active tasks.
- activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of active tasks.
- add(ColumnCondition) - Method in class org.apache.cassandra.cql3.ColumnConditions.Builder
-
Adds the specified ColumnCondition
to this set of conditions.
- add(Operation) - Method in class org.apache.cassandra.cql3.Operations
-
Adds the specified Operation
to this set of operations.
- add(Restrictions) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- add(ByteBuffer) - Method in class org.apache.cassandra.cql3.selection.Selection.ResultSetBuilder
-
- add(Cell, int) - Method in class org.apache.cassandra.cql3.selection.Selection.ResultSetBuilder
-
- add(int, ColumnSpecification) - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- add(Relation) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
-
- add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
-
- add(ByteBuffer) - Method in class org.apache.cassandra.db.CBuilder
-
- add(Object) - Method in class org.apache.cassandra.db.CBuilder
-
- add(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Add a Mutation to the commit log.
- add(T, T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
-
Add an interval to the set and perform normalization.
- add(ColumnDefinition) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
-
- add(ColumnDefinition, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- add(DeletionTime) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- add(CFMetaData, LegacyLayout.LegacyRangeTombstone) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- add(CFMetaData, RangeTombstone) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- add(LegacyLayout.LegacyBound, LegacyLayout.LegacyBound, long, int) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstoneList
-
Adds a new range tombstone.
- add(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- add(ColumnIdentifier) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- add(DeletionTime) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
Potentially replaces the top-level tombstone with another, keeping whichever has the higher markedForDeleteAt
timestamp.
- add(RangeTombstone, ClusteringComparator) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- add(DeletionInfo) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
Combines another DeletionInfo with this one and returns the result.
- add(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.MutableDeletionInfo.Builder
-
- add(PartitionUpdate) - Method in class org.apache.cassandra.db.Mutation
-
Adds PartitionUpdate to the local set of modifications.
- add(ColumnDefinition) - Method in class org.apache.cassandra.db.PartitionColumns.Builder
-
- add(RangeTombstone) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- add(Row) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Adds a row to this update.
- add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- add(ClusteringBound, ClusteringBound, long, int) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Adds a new range tombstone.
- add(int, RangeTombstoneMarker) - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- add(int, Row) - Method in class org.apache.cassandra.db.rows.Row.Merger
-
- add(String, Object) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Adds a value to a given column.
- add(String, Object) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
-
- add(ClusteringBound, ClusteringBound) - Method in class org.apache.cassandra.db.Slices.Builder
-
- add(Slice) - Method in class org.apache.cassandra.db.Slices.Builder
-
- add(View) - Method in class org.apache.cassandra.db.view.TableViews
-
- add(String, FilterPipelineTask<?, ?>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
-
- add(SSTableIndex) - Method in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
-
- add(TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- add(Long, AbstractTokenTreeBuilder.InteriorNode, AbstractTokenTreeBuilder.InteriorNode) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- add(AbstractTokenTreeBuilder.Leaf) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- add(SortedMap<Long, LongSet>) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- add(ByteBuffer, DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- add(ByteBuffer, DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- add(SortedMap<Long, LongSet>) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- add(Long, long) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- add(SortedMap<Long, LongSet>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- add(Iterator<Pair<Long, LongSet>>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- add(TokenTreeBuilder) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.MemIndex
-
- add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
-
- add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex
-
- add(Operator, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- add(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
-
- add(Collection<RowFilter.Expression>) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
-
- add(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SA
-
- add(RangeIterator<K, D>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- add(List<RangeIterator<K, D>>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- add(UnfilteredRowIterator) - Method in class org.apache.cassandra.repair.Validator
-
Called (in order) for every row present in the CF.
- add(Function) - Method in class org.apache.cassandra.schema.Functions.Builder
-
- add(Function...) - Method in class org.apache.cassandra.schema.Functions.Builder
-
- add(Iterable<? extends Function>) - Method in class org.apache.cassandra.schema.Functions.Builder
-
- add(IndexMetadata) - Method in class org.apache.cassandra.schema.Indexes.Builder
-
- add(Iterable<IndexMetadata>) - Method in class org.apache.cassandra.schema.Indexes.Builder
-
- add(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
-
- add(KeyspaceMetadata...) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
-
- add(Iterable<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
-
- add(CFMetaData) - Method in class org.apache.cassandra.schema.Tables.Builder
-
- add(CFMetaData...) - Method in class org.apache.cassandra.schema.Tables.Builder
-
- add(Iterable<CFMetaData>) - Method in class org.apache.cassandra.schema.Tables.Builder
-
- add(TriggerMetadata) - Method in class org.apache.cassandra.schema.Triggers.Builder
-
- add(Iterable<TriggerMetadata>) - Method in class org.apache.cassandra.schema.Triggers.Builder
-
- add(UserType) - Method in class org.apache.cassandra.schema.Types.Builder
-
- add(UserType...) - Method in class org.apache.cassandra.schema.Types.Builder
-
- add(Iterable<UserType>) - Method in class org.apache.cassandra.schema.Types.Builder
-
- add(String, List<String>, List<String>) - Method in class org.apache.cassandra.schema.Types.RawBuilder
-
- add(ViewDefinition) - Method in class org.apache.cassandra.schema.Views.Builder
-
- add(Iterable<ViewDefinition>) - Method in class org.apache.cassandra.schema.Views.Builder
-
- add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- add(String...) - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
-
- add(String, String, Map<InetAddress, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
-
- add(ColumnFamilyStoreMBean) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
-
- add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
-
- add(V) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- add(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
-
- add(E) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
Adds an item to the collection.
- add(Ref<?>) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- add(SelfRefCounted<?>) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- add(SharedCloseable) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- add(SharedCloseableImpl) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- add(Memory) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Increments the count of the bucket closest to n, rounding UP.
- add(long) - Method in class org.apache.cassandra.utils.HistogramBuilder
-
- add(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
-
- add(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Adds an interval to the set, performing the necessary normalization.
- addAggregate(UDAggregate) - Method in class org.apache.cassandra.config.Schema
-
- addAll(IntervalSet<T>) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
-
- addAll(Iterable<ColumnDefinition>) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
-
- addAll(LegacyLayout.LegacyRangeTombstoneList) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstoneList
-
Adds all the range tombstones of tombstones
to this RangeTombstoneList.
- addAll(Iterable<ColumnDefinition>) - Method in class org.apache.cassandra.db.PartitionColumns.Builder
-
- addAll(PartitionColumns) - Method in class org.apache.cassandra.db.PartitionColumns.Builder
-
- addAll(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Adds all the range tombstones of tombstones
to this RangeTombstoneList.
- addAll(Slices) - Method in class org.apache.cassandra.db.Slices.Builder
-
- addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- addAll(Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- addAll(int, Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
-
- addAll(Refs<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Merge two sets of references, ensuring only one reference is retained between the two sets
- addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- addAllElementsToAll(List<List<ByteBuffer>>) - Method in class org.apache.cassandra.db.MultiCBuilder
-
Adds individually each of the specified list of elements to the end of all of the existing composites.
- addAllWithSizeDelta(PartitionUpdate, OpOrder.Group, UpdateTransaction) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
Adds a given update to this in-memtable partition.
- addAndGetIndex(ColumnDefinition, List<ColumnDefinition>) - 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
-
- addAtom(LegacyLayout.LegacyAtom) - Method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
Try adding the provided atom to the currently grouped row.
- addBaseTableUpdate(Row, Row) - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
-
Adds to this generator the updates to be made to the view given a base table row
before and after an update.
- addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- addBootstrapTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- addCallback(IAsyncCallback, MessageOut, InetAddress, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- addCallback(IAsyncCallback, MessageOut<?>, InetAddress, long, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- addCell(ColumnDefinition, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addCell(ColumnDefinition, CellPath, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addCell(Cell) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- addCell(Cell) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
-
- addCell(Cell) - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Adds a cell to this builder.
- addCellPerPartitionCount(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- addClassPath(File) - Method in class org.apache.cassandra.triggers.CustomClassLoader
-
- addClusteringColumn(String, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addClusteringColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
-
- addColumnAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- addColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- addColumnForOrdering(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- addColumnMapping(SelectionColumnMapping, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Record a mapping between the ColumnDefinitions that are used by the selector
instances created by this factory and a column in the ResultSet.Metadata
returned with a query.
- addColumnSpecifications(QueryOptions, List<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- addColumnValue(ByteBuffer) - Method in class org.apache.cassandra.cql3.ResultSet
-
- addComplexDeletion(ColumnDefinition, DeletionTime) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- addComplexDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
-
- addComplexDeletion(ColumnDefinition, DeletionTime) - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Adds a complex deletion.
- addComponents(Collection<Component>) - Method in class org.apache.cassandra.io.sstable.SSTable
-
Registers new custom components.
- addCompressionRatio(long, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
Ratio is compressed/uncompressed and it is
if you have 1.x then compression isn't helping
- addConditions(Clustering, Collection<ColumnCondition>, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- addConditions(Clustering, CQL3CasRequest, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addConditionsTo(CQL3CasRequest, Clustering, QueryOptions) - Method in class org.apache.cassandra.cql3.ColumnConditions
-
Adds the conditions to the specified CAS request.
- addConditionsTo(CQL3CasRequest, Clustering, QueryOptions) - Method in interface org.apache.cassandra.cql3.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(ColumnDefinition, long) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addCounter(ColumnDefinition, long, CellPath) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addCounter(String, Callable<Integer>) - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- addCustomIndexExpression(CFMetaData, IndexMetadata, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- addDefinition(ColumnIdentifier, CQL3Type.Raw, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- addDefinition(FieldIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- 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
-
- addEachElementToAll(List<ByteBuffer>) - Method in class org.apache.cassandra.db.MultiCBuilder
-
Adds individually each of the specified elements to the end of all of the existing clusterings.
- added - Variable in class org.apache.cassandra.notifications.InitialSSTableAddedNotification
-
true
if the addition corresponds to the
ColumnFamilyStore
initialization, then the sstables
are those loaded at startup.
- added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
-
- 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(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
-
- Adder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
-
- AdderByKey(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.AdderByKey
-
- addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlLexer
-
- addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlParser
-
- addEventListener(StreamEventHandler) - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- addExclusion(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- addExist(Clustering) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- addExpireTimeForEndpoint(InetAddress, long) - Method in class org.apache.cassandra.gms.Gossiper
-
- addExpireTimeIfFound(InetAddress, long) - Method in class org.apache.cassandra.service.StorageService
-
- addFailedSnapshot(File) - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
-
- addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- addFunction(UDFunction) - Method in class org.apache.cassandra.config.Schema
-
- addFunctions(Iterable<Term>, List<Function>) - Static method in class org.apache.cassandra.cql3.Terms
-
- 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.ColumnCondition
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.ColumnConditions
-
- addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.Conditions
-
Adds the functions used by the conditions to the specified list.
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.functions.Function
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Operation
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Operations
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Adds all functions (native and user-defined) used by any component of the restriction
to the specified list.
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestriction
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.TermSlice
-
- 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 class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- addHistogram(long[], long[]) - Static method in class org.apache.cassandra.metrics.TableMetrics
-
- 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) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Adds and builds a index
- addIndexClusteringColumns(CFMetaData.Builder, CFMetaData, ColumnDefinition) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
-
Add the clustering columns for a specific type of index table to the a CFMetaData.Builder (which is being
used to construct the index table's CFMetadata.
- addIndexClusteringColumns(CFMetaData.Builder, CFMetaData, ColumnDefinition) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
-
- addInitialDirectories(Directories.DataDirectory[]) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
A hook to add additional directories to initialDirectories.
- addInitialSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- addInitialSSTablesWithoutUpdatingSize(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- addInput(ProtocolVersion, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Adds the specified input to this aggregate.
- addInput(ProtocolVersion, Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.Selector
-
Add the current value from the specified ResultSetBuilder
.
- addInput(ProtocolVersion, Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- addInput(ProtocolVersion, Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.TermSelector
-
- Addition(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Addition
-
- addition(UTName, FieldIdentifier, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- additionalHeaderParameters() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- additionalHeaderParameters() - Method in class org.apache.cassandra.db.commitlog.EncryptedSegment
-
- addKey(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- addKeyAliases(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- addKeyspace(KeyspaceMetadata) - Method in class org.apache.cassandra.config.Schema
-
- addLatency(InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
-
- addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- addLocalApplicationStates(List<Pair<ApplicationState, VersionedValue>>) - Method in class org.apache.cassandra.gms.Gossiper
-
- addMapEquality(ColumnDefinition, ByteBuffer, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- addMapping(ColumnSpecification, ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- addMapping(ColumnSpecification, Iterable<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- addMerkleTree(int, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Add a MerkleTree with the defined size and range.
- addMerkleTree(int, byte, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
- addMerkleTrees(int, Collection<Range<Token>>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Add merkle tree's with the defined maxsize and ranges.
- addMessageSink(IMessageSink) - Method in class org.apache.cassandra.net.MessagingService
-
- addMovingEndpoint(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Add a new moving endpoint
- addNano(long) - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
takes nanoseconds
- addNonSerializedColumn(ColumnSpecification) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
Adds the specified column which will not be serialized.
- addNonShadowed(Cell, Cell, DeletionTime, Row.Builder, int) - 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(ColumnDefinition, Iterator<Cell>, Iterator<Cell>, DeletionTime, Row.Builder, int) - Static method in class org.apache.cassandra.db.rows.Cells
-
Adds to the builder a representation of the given existing cell that, when merged/reconciled with the given
update cell, produces the same result as merging the original with the update.
- addNotExist(Clustering) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- addOffset(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- addOption(String, String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option with argument and argument name
- addOption(String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option without argument
- addOrderingColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- addOrReplaceColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- addPartitionDeletion(DeletionTime) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- addPartitionKey(String, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addPartitionKey(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addPartitionSizeInBytes(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- addPendingRange(Range<Token>, InetAddress) - Method in class org.apache.cassandra.locator.PendingRangeMaps
-
- addPostShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
-
Add a runnable which will be called after shutdown or drain.
- addPreShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
-
Add a runnable which will be called before shut down or drain.
- addPrimaryKeyLivenessInfo() - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addPrimaryKeyLivenessInfo(LivenessInfo) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- addPrimaryKeyLivenessInfo(LivenessInfo) - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Adds the liveness information for the partition key columns of this row.
- addProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- addProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
-
- addProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
-
Register progress listener to this publisher.
- addProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
-
- addProperty(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- addProperty(String, Map<String, String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- addr - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- addRangeDeletion(Slice, ModificationStatement, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- addRangeForEndpoint(Range<Token>, InetAddress) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- addRanges(String, Collection<Range<Token>>) - Method in class org.apache.cassandra.dht.RangeStreamer
-
Add ranges to be streamed for given keyspace.
- 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
-
- addRawUpdate(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw, Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- addRecognitionError(String) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- addRecognitionError(String) - Method in class org.apache.cassandra.cql3.CqlParser
-
- addRegularColumn(String, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addRegularColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addReplaceTokens(Collection<Token>, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- address - Variable in class org.apache.cassandra.dht.BootStrapper
-
- address - Variable in class org.apache.cassandra.locator.InetAddressAndPort
-
- address - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
- address - Variable in class org.apache.cassandra.thrift.ThriftServer
-
- addressBytes - Variable in class org.apache.cassandra.locator.InetAddressAndPort
-
- addRow(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.ResultSet
-
- addRow(Object...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer.
- addRow(List<Object>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer.
- addRow(Map<String, Object>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer.
- addRowDeletion() - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addRowDeletion(Row.Deletion) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- addRowDeletion(Row.Deletion) - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Adds the deletion information for this row.
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Adds to the specified row filter the expressions corresponding to this Restriction
.
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyEQRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeySliceRestriction
-
- addRowFilterTo(RowFilter, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- addRowUpdate(Clustering, ModificationStatement, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- addSample(T) - Method in class org.apache.cassandra.utils.TopKSampler
-
- addSample(T, long, int) - Method in class org.apache.cassandra.utils.TopKSampler
-
Adds a sample to statistics collection.
- addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Add an endpoint we knew about previously, but whose state is unknown
- addSessionInfo(SessionInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- addSlice(Slice) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.SinglePartitionSliceBuilder
-
- addSourceFilter(RangeStreamer.ISourceFilter) - Method in class org.apache.cassandra.dht.RangeStreamer
-
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Adds sstable, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Adds sstables, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)
- addSSTables(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
-
- addStaticColumn(String, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addStaticColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.config.CFMetaData.Builder
-
- addStreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Method in class org.apache.cassandra.streaming.StreamSession
-
Request data fetch task to this session.
- addTable(CFMetaData) - Method in class org.apache.cassandra.config.Schema
-
- addTableToSchemaMutation(CFMetaData, boolean, Mutation.SimpleBuilder) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- addThriftExpression(CFMetaData, ByteBuffer, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- addTimeTaken(InetAddress, long) - Method in class org.apache.cassandra.metrics.MessagingMetrics
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.util.FileHandle
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.BloomFilter
-
- addTo(Ref.IdentityCollection) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- addTo(Ref.IdentityCollection) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- addTombstone(ColumnDefinition) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addTombstone(ColumnDefinition, CellPath) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- addToRawBuilder(Types.RawBuilder) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- addToRowFilter(RowFilter, CFMetaData, 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
-
- addTransferFile(Ref<SSTableReader>, long, List<Pair<Long, Long>>, long) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- addTransferFiles(Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamSession
-
- addTransferRanges(String, Collection<Range<Token>>, Collection<String>, boolean, long) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set up transfer for specific keyspace/ranges/CFs
Used in repair - a streamed sstable in repair will be marked with the given repairedAt time
- addTrueNegative() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- addType(UserType) - Method in class org.apache.cassandra.config.Schema
-
- 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, Clustering, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
-
- addUpdateForKey(PartitionUpdate, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
-
- addUpdateForKey(PartitionUpdate, Clustering, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addUpdateForKey(PartitionUpdate, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addUpdateForKey(PartitionUpdate, Clustering, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
-
- addUpdateForKey(PartitionUpdate, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
-
- addUserExpression(RowFilter.UserExpression) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- addView(ViewDefinition) - Method in class org.apache.cassandra.config.Schema
-
- addView(ViewDefinition) - Method in class org.apache.cassandra.db.view.ViewManager
-
- adjust(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
-
Like allocate, but permits allocations to be negative.
- advance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
-
- advertiseRemoving(InetAddress, UUID, UUID) - Method in class org.apache.cassandra.gms.Gossiper
-
This method will begin removing an existing endpoint from the cluster by spoofing its state
This should never be called unless this coordinator has had 'removenode' invoked
- advertiseTokenRemoved(InetAddress, UUID) - Method in class org.apache.cassandra.gms.Gossiper
-
Handles switching the endpoint's state from REMOVING_TOKEN to REMOVED_TOKEN
This should only be called after advertiseRemoving
- affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
-
- affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
-
- affectedColumn() - Method in 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.
- afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- AGGREGATE_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
AggregationSpecification
that group all the row together.
- AggregateFcts - Class in org.apache.cassandra.cql3.functions
-
Factory methods for aggregate functions.
- AggregateFcts() - Constructor for class org.apache.cassandra.cql3.functions.AggregateFcts
-
- AggregateFunction - Interface in org.apache.cassandra.cql3.functions
-
Performs a calculation on a set of values and return a single value.
- AggregateFunction.Aggregate - Interface in org.apache.cassandra.cql3.functions
-
An aggregation operation.
- aggregatePkPrefix(ClusteringComparator, int) - Static method in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
Creates a new AggregationSpecification
instance that will build aggregates based on primary key
columns.
- AGGREGATES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- aggregatesUsingFunction(Function) - Method in class org.apache.cassandra.schema.Functions
-
- AggregationPartitionIterator(int, ConsistencyLevel, ClientState, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
-
- AggregationPartitionIterator(int, ReadExecutionController, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
-
- AggregationQueryPager - Class in org.apache.cassandra.service.pager
-
QueryPager
that takes care of fetching the pages for aggregation queries.
- AggregationQueryPager(QueryPager, DataLimits) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager
-
- AggregationQueryPager.AggregationPartitionIterator - Class in org.apache.cassandra.service.pager
-
PartitionIterator
for queries without Group By but with aggregates.
- AggregationQueryPager.GroupByPartitionIterator - Class in org.apache.cassandra.service.pager
-
PartitionIterator
that automatically fetch a new sub-page of data if needed when the current iterator is
exhausted.
- AggregationSpecification - Class in org.apache.cassandra.db.aggregation
-
Defines how rows should be grouped for creating aggregates.
- AggregationSpecification.Kind - Enum in org.apache.cassandra.db.aggregation
-
The AggregationSpecification
kinds.
- AggregationSpecification.Serializer - Class in org.apache.cassandra.db.aggregation
-
- algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- alias - Variable in class org.apache.cassandra.cql3.selection.RawSelector
-
- aliasFactory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
- 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
-
- ALL - Static variable in enum org.apache.cassandra.auth.Permission
-
- all - Static variable in interface org.apache.cassandra.concurrent.ExecutorLocal
-
- all() - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
-
- all() - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- all() - Static method in class org.apache.cassandra.cql3.functions.CastFcts
-
- all() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
-
- all() - Static method in class org.apache.cassandra.cql3.functions.UuidFcts
-
- all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- all(CFMetaData) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
-
A filter that includes all columns for the provided table.
- all() - Static method in class org.apache.cassandra.db.Keyspace
-
- ALL - Static variable in class org.apache.cassandra.db.Slice
-
The slice selecting all rows (of a given partition)
- ALL - Static variable in class org.apache.cassandra.db.Slices
-
Slices selecting all the rows of a partition.
- all - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
Stores all metric names created that can be used when unregistering, optionally mapped to an alias name.
- all - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
-
- all - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
-
- ALL - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
The order in this list matters.
- all(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
- ALL_FOR_DIGEST - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
Until we upgrade the messaging service version, that is version 4.0, we must preserve the old order (before
CASSANDRA-12213) for digest calculations, otherwise the nodes will never agree on the schema during a rolling
upgrade, see CASSANDRA-13559.
- ALL_MUTATIONS - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReader
-
- ALL_TABLE_METADATA - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
-
- allChannels - Variable in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- allColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- allColumnsBuilder(CFMetaData) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
-
Returns a ColumnFilter
} builder that fetches all columns (and queries the columns
added to the builder, or everything if no column is added).
- allColumnsInSelectOrder() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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(CFMetaData, int) - Static method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
Creates a new read command that query all the data in the table.
- allFetchedColumnsAreQueried() - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
Whether _fetched_ == _queried_ for this filter, and so if the isQueried()
methods
can return false
for some column/cell.
- allInSameTable(Collection<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.ColumnSpecification
-
Returns true if all ColumnSpecifications are in the same table, false otherwise.
- allKnownSSTables() - Method in class org.apache.cassandra.db.lifecycle.View
-
- 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.
- allMemtablesOffHeapSize - 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.
- allMemtablesOnHeapSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total amount of data stored in the memtables (2i and pending flush memtables included) that resides on-heap.
- allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Allocate a segment within this CLSM.
- allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
Reserve space in the current segment for the provided mutation or, if there isn't space available,
create a new segment.
- allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
-
Reserve space in the current segment for the provided mutation or, if there isn't space available,
create a new segment.
- allocate(int, int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
Allocate a new context big enough for globalCount + localCount + remoteCount elements
and return the initial corresponding ContextState.
- allocate(int) - Method in enum org.apache.cassandra.io.compress.BufferType
-
- allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
-
- allocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
-
- allocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
-
- allocate(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
-
Allocates an amount independent of permits available from this limit.
- allocate(int) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.memory.HeapAllocator
-
- allocate(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- allocate(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
-
- allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- ALLOCATE_ON_HEAP_WHEN_EXAHUSTED - Static variable in class org.apache.cassandra.utils.memory.BufferPool
-
- 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
- allocateBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
-
Allocate buffer using set buffer type and buffer size.
- allocated(long) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
-
- allocated(long) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
-
- allocateTokens(TokenMetadata, AbstractReplicationStrategy, InetAddress, int) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
-
- allocatingOnHeap() - Method in class org.apache.cassandra.utils.memory.HeapAllocator
-
- allocator - Static variable in class org.apache.cassandra.transport.CBUtil
-
- allocator(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- allocator(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- allOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- 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_insecure_udfs - Variable in class org.apache.cassandra.config.Config
-
Set this to true to allow running insecure UDFs.
- AllowAllAuthenticator - Class in org.apache.cassandra.auth
-
- AllowAllAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllAuthenticator
-
- AllowAllAuthorizer - Class in org.apache.cassandra.auth
-
- AllowAllAuthorizer() - Constructor for class org.apache.cassandra.auth.AllowAllAuthorizer
-
- AllowAllInternodeAuthenticator - Class in org.apache.cassandra.auth
-
- AllowAllInternodeAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- allowClusteringColumnSlices() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks this type of statement allow the where clause to contains clustering column slices.
- allowedFunctionName() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- allowedFunctionName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AllowedSourcesFilter(Set<InetAddress>) - 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
-
- allowIncomingMessage(MessageIn, int) - Method in interface org.apache.cassandra.net.IMessageSink
-
Allow or drop an incoming message
- allowInsecureUDFs() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- allowNewUpdates() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
If a partition update has been read (and is thus unmodifiable), a call to this method
makes the update modifiable again.
- allowNonPrimaryKeyInWhereClause() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks if this type of statement allow non primary key in the where clause.
- allowOutgoingMessage(MessageOut, int, InetAddress) - Method in interface org.apache.cassandra.net.IMessageSink
-
Allow or drop an outgoing message
- 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.
- allowUseOfSecondaryIndices() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks if this type of statement allow the use of secondary indices.
- allTableMetrics - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
stores metrics that will be rolled into a single global metric
- allTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- allViewsCfs() - Method in class org.apache.cassandra.db.view.TableViews
-
- AlreadyExistsException - Exception in org.apache.cassandra.exceptions
-
- AlreadyExistsException(String, String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- AlreadyExistsException(String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- alter(UTName, FieldIdentifier, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- alterableOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- alterableOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Subset of supportedOptions that users are allowed to alter when performing ALTER ROLE [themselves].
- alterKeyspaceStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterKeyspaceStatement(String, KeyspaceAttributes) - Constructor for class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- alterMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of ALTER ROLE statement.
- alterRoleStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterRoleStatement(RoleName, RoleOptions) - Constructor for class org.apache.cassandra.cql3.statements.AlterRoleStatement
-
- alterTableStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterTableStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterTableStatement(CFName, AlterTableStatement.Type, List<AlterTableStatementColumn>, TableAttributes, Map<ColumnDefinition.Raw, ColumnDefinition.Raw>, Long) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- AlterTableStatement.Type - Enum in org.apache.cassandra.cql3.statements
-
- AlterTableStatementColumn - Class in org.apache.cassandra.cql3.statements
-
Stores a column name and optionally type for an Alter Table statement definition.
- AlterTableStatementColumn(ColumnDefinition.Raw, CQL3Type.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatementColumn
-
- AlterTableStatementColumn(ColumnDefinition.Raw, CQL3Type.Raw) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatementColumn
-
- AlterTableStatementColumn(ColumnDefinition.Raw) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatementColumn
-
- alterTypeStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterTypeStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterTypeStatement(UTName) - Constructor for class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- alterUserStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- alterUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterViewStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterViewStatement(CFName, TableAttributes) - Constructor for class org.apache.cassandra.cql3.statements.AlterViewStatement
-
- ALWAYS - Static variable in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- always() - Static method in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- alwaysLowerCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
- AlwaysPresent - Static variable in class org.apache.cassandra.utils.FilterFactory
-
- AlwaysPresentFilter - Class in org.apache.cassandra.utils
-
- AlwaysPresentFilter() - Constructor for class org.apache.cassandra.utils.AlwaysPresentFilter
-
- alwaysUpperCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
- analyzeGroup(QueryController, Operation.OperationType, List<RowFilter.Expression>) - Static method in class org.apache.cassandra.index.sasi.plan.Operation
-
- analyzer - Variable in class org.apache.cassandra.index.sasi.plan.Expression
-
- analyzerClass - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- announceAggregateDrop(UDAggregate, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyDrop(String, String) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyDrop(String, String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData, Collection<ViewDefinition>, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceFunctionDrop(UDFunction, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceDrop(String) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceDrop(String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceUpdate(KeyspaceMetadata) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceUpdate(KeyspaceMetadata, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.AlterViewStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateViewStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.DropViewStatement
-
- announceMigration(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
Announces the migration to other nodes in the cluster.
- announceNewAggregate(UDAggregate, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewColumnFamily(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewFunction(UDFunction, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewKeyspace(KeyspaceMetadata) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewKeyspace(KeyspaceMetadata, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewKeyspace(KeyspaceMetadata, long, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewType(UserType, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewView(ViewDefinition, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceTypeDrop(UserType) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceTypeDrop(UserType, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceTypeUpdate(UserType, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceViewDrop(String, String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceViewUpdate(ViewDefinition, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceWithoutPush(Collection<Mutation>) - Static method in class org.apache.cassandra.service.MigrationManager
-
- ANONYMOUS_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- ANONYMOUS_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- AnticompactionCallback(AnticompactionTask) - Constructor for class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
-
- AnticompactionRequest - Class in org.apache.cassandra.repair.messages
-
- AnticompactionRequest(UUID, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.AnticompactionRequest
-
- AnticompactionRequest.AnticompactionRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- AnticompactionRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- AnticompactionTask - Class in org.apache.cassandra.repair
-
- AnticompactionTask(UUID, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.AnticompactionTask
-
- AnticompactionTask.AnticompactionCallback - Class in org.apache.cassandra.repair
-
Callback for antitcompaction request.
- any(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
- anyCauseMatches(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.utils.Throwables
-
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Writes a partition in an implementation specific way
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
Appends partition data to this writer.
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Appends partition data to this writer.
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- append(UnfilteredRowIterator) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
Writes a partition in an implementation specific way
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- append(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- append(E) - Method in class org.apache.cassandra.utils.DynamicList
-
- append(E, int) - Method in class org.apache.cassandra.utils.DynamicList
-
- append(E, int) - Method in class org.apache.cassandra.utils.LockedDynamicList
-
- appendAll(String, Object) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Appends new values to a given non-frozen collection column.
- appendAll(String, Object) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
-
- appendAndSync(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyEQRestriction
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeySliceRestriction
-
- appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiSliceRestriction
-
- 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.
- 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(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Appender
-
- appendKeyString(StringBuilder, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.db.DataRange
-
- appendOrderByToCQLString(CFMetaData, StringBuilder) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
Appends the values of this SingleRestriction
to the specified builder.
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiEQRestriction
-
- appendTo(MultiCBuilder, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
Appends the values of this SingleRestriction
to the specified builder.
- appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Appends new component names to the TOC component.
- 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
-
- ApplicationState - Enum in org.apache.cassandra.gms
-
The various "states" exchanged through Gossip.
- appliesLocally(Mutation) - Method in class org.apache.cassandra.service.StorageProxy
-
- appliesOnlyToStaticColumns(Operations, Conditions) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
Checks that the specified operations and conditions only apply to static columns.
- appliesTo(Row) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
Validates whether this condition applies to current
.
- appliesTo(Row) - Method in class org.apache.cassandra.cql3.ColumnCondition.CollectionInBound
-
- appliesTo(Row) - Method in class org.apache.cassandra.cql3.ColumnCondition.UDTInBound
-
- appliesTo(FilteredPartition) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
Checks whether the conditions represented by this object applies provided the current state of the partition on
which those conditions are.
- appliesTo(FilteredPartition) - Method in interface org.apache.cassandra.service.CASRequest
-
Returns whether the provided CF, that represents the values fetched using the
readFilter(), match the CAS conditions this object stands for.
- appliesToRegularColumns() - Method in class org.apache.cassandra.cql3.ColumnConditions
-
- appliesToRegularColumns() - Method in interface org.apache.cassandra.cql3.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.ColumnConditions
-
- appliesToStaticColumns() - Method in interface org.apache.cassandra.cql3.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(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
Updates CFMetaData in-place to match cfm
- apply(PartitionUpdate, UpdateTransaction, OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Insert/Update the column family for this key.
- apply(Consumer<ColumnDefinition>, boolean) - Method in class org.apache.cassandra.db.Columns
-
Apply a function to each column definition in forwards or reversed order.
- apply() - Method in class org.apache.cassandra.db.CounterMutation
-
- apply() - Method in interface org.apache.cassandra.db.IMutation
-
- apply(Mutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
- apply(Mutation, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
- apply(Mutation, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
If apply is blocking, apply must not be deferred
Otherwise there is a race condition where ALL mutation workers are being blocked ending
in a complete deadlock of the mutation stage.
- apply(boolean, boolean) - Method in class org.apache.cassandra.db.Mutation
-
- apply(boolean) - Method in class org.apache.cassandra.db.Mutation
-
- apply() - Method in class org.apache.cassandra.db.Mutation
-
- apply(Consumer<ColumnData>, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- apply(Consumer<ColumnData>, Predicate<ColumnData>, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- apply(Consumer<ColumnData>, boolean) - Method in interface org.apache.cassandra.db.rows.Row
-
Apply a function to every column in a row
- apply(Consumer<ColumnData>, Predicate<ColumnData>, boolean) - Method in interface org.apache.cassandra.db.rows.Row
-
Apply a funtion to every column in a row until a stop condition is reached
- apply(UnfilteredPartitionIterator, Transformation<? super UnfilteredRowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
-
- apply(PartitionIterator, Transformation<? super RowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
-
- apply(UnfilteredRowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
-
- apply(RowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
-
- apply(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(Set<S>, long, TimeUnit) - Method in interface org.apache.cassandra.net.BackPressureStrategy
-
Applies the back-pressure algorithm, based and acting on the given
BackPressureState
s, and up to the given
timeout.
- apply(Set<RateBasedBackPressureState>, long, TimeUnit) - Method in class org.apache.cassandra.net.RateBasedBackPressure
-
- apply(IMutation, Iterable<InetAddress>, AbstractWriteResponseHandler<IMutation>, String, ConsistencyLevel) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
-
- apply(Object[], Consumer<V>, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Simple method to walk the btree forwards or reversed and apply a function to each element
Public method
- apply(Object[], Consumer<V>, Predicate<V>, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Simple method to walk the btree forwards or reversed and apply a function till a stop condition is reached
Public method
- apply(V, K) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
-
- apply(V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
-
- apply(V, V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
-
- applyAddressConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyAddressConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyAuth() - Static method in class org.apache.cassandra.auth.AuthConfig
-
- applyBackPressure(Iterable<InetAddress>, long) - Method in class org.apache.cassandra.net.MessagingService
-
Applies back-pressure for the given hosts, according to the configured strategy.
- applyConfig() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- applyConfigChanges() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
Update configuration from
DatabaseDescriptor
and estart the update-scheduler and reset-scheduler tasks
if the configured rates for these tasks have changed.
- applyCounterMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
Applies the counter mutation, returns the result Mutation (for replication to other nodes).
- applyCounterMutationOnCoordinator(CounterMutation, String, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- applyCounterMutationOnLeader(CounterMutation, String, Runnable, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- applyEncryptionContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyFuture(Mutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
- applyFuture(Mutation, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
- applyFuture() - Method in class org.apache.cassandra.db.Mutation
-
- applyOne(BaseRowIterator<?>, Transformation) - Method in class org.apache.cassandra.db.transform.BasePartitions
-
- applyOne(Unfiltered, Transformation) - Method in class org.apache.cassandra.db.transform.BaseRows
-
- applyPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applySeedProvider() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applySnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyStateTransition(Message.Type, Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
-
- applyThriftHSHA() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyTo(PartitionIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyTo(UnfilteredPartitionIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyTo(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyTo(RowIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyToChannel(Function<WritableByteChannel, R>) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- applyToChannel(Function<WritableByteChannel, R>) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Safe way to operate against the underlying channel.
- applyToChannel(Function<WritableByteChannel, R>) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
-
- applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to the partition-level deletion of any rows iterator.
- applyToDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyTokensConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.Filter
-
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to any RTM we encounter in a rows/unfiltered iterator
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToPartition(BaseRowIterator<?>) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyToPartition(DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.ReadCommand.CheckForAbort
-
- applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.EmptyPartitionsDiscarder
-
- applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.Filter
-
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.transform.RTBoundCloser
-
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.transform.RTBoundValidator
-
- applyToPartition(I) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to any rows iterator (partition) we encounter in a partitions iterator
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.thrift.ThriftResultsMerger
-
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToPartition(SearchIterator<Clustering, Row>) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToPartition(Iterator<Row>) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToPartitionColumns(PartitionColumns) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
-
- applyToPartitionColumns(PartitionColumns) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to the PartitionColumns
of any rows iterator.
- applyToPartitionKey(DecoratedKey) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to the partition key of any rows/unfiltered iterator we are applied to
- applyToPartitionKey(DecoratedKey) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.ReadCommand.CheckForAbort
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.transform.Filter
-
- applyToRow(Row) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to any row we encounter in a rows iterator
- applyToRow(Row) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyToStatic(Row) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- applyToStatic(Row) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
-
- applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.Filter
-
- applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to the static row of any rows iterator.
- applyToStatic(Row) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
-
- applyUnsafe() - Method in class org.apache.cassandra.db.Mutation
-
- ApproximateTime - Class in org.apache.cassandra.db.monitoring
-
This is an approximation of System.currentTimeInMillis().
- ApproximateTime() - Constructor for class org.apache.cassandra.db.monitoring.ApproximateTime
-
- Architecture - Class in org.apache.cassandra.utils
-
- archivePending - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- archiver - Variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- areAllNodesAtLeast22() - Method in class org.apache.cassandra.net.MessagingService
-
- areAllNodesAtLeast30() - Method in class org.apache.cassandra.net.MessagingService
-
- argCodecs - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- argNames - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- argNames() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- args - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
-
- args - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
-
- Args() - Constructor for class org.apache.cassandra.thrift.TServerFactory.Args
-
- argTypes - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argTypes() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argTypes() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- argTypes - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- argTypes - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- arrayCopy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- arrayCopy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Transfer bytes from one ByteBuffer to another.
- asAlteredKeyspaceParams(KeyspaceParams) - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- asAlteredTableParams(TableParams) - Method in class org.apache.cassandra.cql3.statements.TableAttributes
-
- asByteBuffer(long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- asByteBuffers(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- asBytes(String, String, AbstractType) - Static method in class org.apache.cassandra.cql3.Terms
-
- asc(boolean) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
-
- asCell() - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
- asCell() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- asCell() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- AsciiSerializer - Class in org.apache.cassandra.serializers
-
- AsciiType - Class in org.apache.cassandra.db.marshal
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ByteType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DurationType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.LongType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ShortType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UserType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- asCqlString(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.IndexTarget
-
- asCQLTypeStringList(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.AbstractType
-
- asInt() - Method in enum org.apache.cassandra.transport.ProtocolVersion
-
- asJavaClass(TypeCodec<?>) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- ask() - Method in class org.apache.cassandra.utils.concurrent.Blocker
-
- asList() - Method in class org.apache.cassandra.dht.Range
-
- asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- asMap() - Method in class org.apache.cassandra.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
-
- asNativeFunction() - Method in class org.apache.cassandra.cql3.functions.FunctionName
-
- asNewBuffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- asNewKeyspaceParams() - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- asNewTableParams() - Method in class org.apache.cassandra.cql3.statements.TableAttributes
-
- asNonCompact() - Method in class org.apache.cassandra.config.CFMetaData
-
Returns a cached non-compact version of this table.
- asRangeTombstone() - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
- asRangeTombstone() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- asRangeTombstone() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- 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
-
- assertUdfsEnabled(String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
- AssignmentTestable - Interface in org.apache.cassandra.cql3
-
- AssignmentTestable.TestResult - Enum in org.apache.cassandra.cql3
-
- assumeLiveData - Variable in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- assureSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.ReadCallback
-
- asymmetricCellPathComparator() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- asymmetricColumnDataComparator - Static variable in class org.apache.cassandra.config.ColumnDefinition
-
- AsymmetricOrdering<T1,T2> - Class in org.apache.cassandra.utils
-
- AsymmetricOrdering() - Constructor for class org.apache.cassandra.utils.AsymmetricOrdering
-
- AsymmetricOrdering.Op - Enum in org.apache.cassandra.utils
-
- ASYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer.ThriftServerType
-
- 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
-
- asyncRemoveFromBatchlog(Collection<InetAddress>, UUID, long) - Static method in class org.apache.cassandra.batchlog.LegacyBatchlogMigrator
-
- AsyncRepairCallback - Class in org.apache.cassandra.service
-
- AsyncRepairCallback(DataResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
-
- 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.
- atomic_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- AtomicBTreePartition - Class in org.apache.cassandra.db.partitions
-
A thread-safe and atomic Partition implementation.
- AtomicBTreePartition(CFMetaData, DecoratedKey, MemtableAllocator) - Constructor for class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
- attach(AbstractCommitLogService, AbstractCommitLogSegmentManager) - Method in class org.apache.cassandra.metrics.CommitLogMetrics
-
- attach(Connection) - Method in class org.apache.cassandra.transport.Message
-
- attachTo(BasePartitions) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- attachTo(BaseRows) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- attachTo(BasePartitions) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
-
- attachTo(BaseRows) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
-
- attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- 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
-
- augment(Partition) - Method in interface org.apache.cassandra.triggers.ITrigger
-
Called exactly once per CF update, returned mutations are atomically updated.
- AUTH_KEYSPACE_NAME - Static variable in class org.apache.cassandra.config.SchemaConstants
-
- AUTH_PROVIDER_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- AuthCache<K,V> - Class in org.apache.cassandra.auth
-
- AuthCache(String, Consumer<Integer>, Supplier<Integer>, Consumer<Integer>, Supplier<Integer>, Consumer<Integer>, Supplier<Integer>, Function<K, V>, Supplier<Boolean>) - Constructor for class org.apache.cassandra.auth.AuthCache
-
- AuthCacheMBean - Interface in org.apache.cassandra.auth
-
- AuthChallenge - Class in org.apache.cassandra.transport.messages
-
SASL challenge sent from client to server
- AuthChallenge(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthChallenge
-
- AuthConfig - Class in org.apache.cassandra.auth
-
- AuthConfig() - Constructor for class org.apache.cassandra.auth.AuthConfig
-
- authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Decides whether or not a peer is allowed to connect to this node.
- authenticate(Object) - Method in class org.apache.cassandra.auth.jmx.AuthenticationProxy
-
Perform authentication of the client opening the MBeanServerConnection
- AuthenticatedUser - Class in org.apache.cassandra.auth
-
Returned from IAuthenticator#authenticate(), represents an authenticated user everywhere internally.
- AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
-
- AuthenticateMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- AuthenticateMessage(String) - Constructor for class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthenticationException - Exception in org.apache.cassandra.exceptions
-
- AuthenticationException(String) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
-
- AuthenticationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
-
- AuthenticationProxy - Class in org.apache.cassandra.auth.jmx
-
An alternative to the JAAS based implementation of JMXAuthenticator provided
by the JDK (JMXPluggableAuthenticator).
- AuthenticationProxy(String) - Constructor for class org.apache.cassandra.auth.jmx.AuthenticationProxy
-
Creates an instance of JMXPluggableAuthenticator
and initializes it with a LoginContext
.
- AuthenticationStatement - Class in org.apache.cassandra.cql3.statements
-
- AuthenticationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- authenticator - Variable in class org.apache.cassandra.config.Config
-
- authenticator - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthKeyspace - Class in org.apache.cassandra.auth
-
- AuthMetrics - Class in org.apache.cassandra.metrics
-
Metrics about authentication
- AuthMigrationListener - Class in org.apache.cassandra.auth
-
MigrationListener implementation that cleans up permissions on dropped resources.
- AuthMigrationListener() - Constructor for class org.apache.cassandra.auth.AuthMigrationListener
-
- AuthorizationProxy - Class in org.apache.cassandra.auth.jmx
-
Provides a proxy interface to the platform's MBeanServer instance to perform
role-based authorization on method invocation.
- AuthorizationProxy() - Constructor for class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- AuthorizationStatement - Class in org.apache.cassandra.cql3.statements
-
- AuthorizationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Returns a set of permissions of a user on a resource.
- authorizer - Variable in class org.apache.cassandra.config.Config
-
- authProvider - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- AuthResponse - Class in org.apache.cassandra.transport.messages
-
A SASL token message sent from client to server.
- AuthResponse(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthResponse
-
- AuthSuccess - Class in org.apache.cassandra.transport.messages
-
Indicates to the client that authentication has succeeded.
- AuthSuccess(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthSuccess
-
- auto(boolean) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- auto_bootstrap - Variable in class org.apache.cassandra.config.Config
-
- auto_snapshot - Variable in class org.apache.cassandra.config.Config
-
- AutoSavingCache<K extends CacheKey,V> - Class in org.apache.cassandra.cache
-
- AutoSavingCache(ICache<K, V>, CacheService.CacheType, AutoSavingCache.CacheSerializer<K, V>) - Constructor for class org.apache.cassandra.cache.AutoSavingCache
-
- AutoSavingCache.CacheSerializer<K extends CacheKey,V> - Interface in org.apache.cassandra.cache
-
- AutoSavingCache.IStreamFactory - Interface in org.apache.cassandra.cache
-
- AutoSavingCache.Writer - Class in org.apache.cassandra.cache
-
- available() - Method in class org.apache.cassandra.io.util.DataInputBuffer
-
- available() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Returns the number of bytes that are available before this stream will
block.
- available() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- available() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- available() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- available() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- available() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- AVAILABLE_RANGES - 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.service.paxos.AbstractPaxosCallback
-
- await(long, TimeUnit) - Method in class org.apache.cassandra.service.ReadCallback
-
- await() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
wait for all operations started prior to issuing the barrier to complete
- await() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- await() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- await(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- await() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
-
- await() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Wait until signalled, or throw an InterruptedException if interrupted before this happens.
- awaitCompletion() - Method in class org.apache.cassandra.tools.BootstrapMonitor
-
- awaitNanos(long) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- awaitNewBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
- awaitResults() - Method in class org.apache.cassandra.service.ReadCallback
-
- awaitSchemaRequests(long) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
Wait until we've received schema responses for all versions we're aware of
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
-
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Returns when the management thread terminates.
- awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- awaitTermination(long, TimeUnit, ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- awaitTermination(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- awaitTerminationUntil(long, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
-
- awaitUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Wait, without throwing InterruptedException, until signalled.
- awaitUntil(Date) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
-
- awaitUntil(long) - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Wait until signalled, or the provided time is reached, or the thread is interrupted.
- C - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- C - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- C - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- C - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- 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_seconds - Variable in class org.apache.cassandra.config.Config
-
- CACHE_NOTHING - Static variable in class org.apache.cassandra.schema.CachingParams
-
- cacheAllRows() - Method in class org.apache.cassandra.schema.CachingParams
-
- cached_rows_fail_threshold - Variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
-
- cached_rows_warn_threshold - Variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
-
- CachedBTreePartition - Class in org.apache.cassandra.db.partitions
-
- CachedHashDecoratedKey - Class in org.apache.cassandra.db
-
- CachedHashDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.CachedHashDecoratedKey
-
- cachedLiveRows() - Method in class org.apache.cassandra.db.partitions.CachedBTreePartition
-
The number of rows that were live at the time the partition was cached.
- cachedLiveRows() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
-
The number of rows that were live at the time the partition was cached.
- cachedOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return a cached TokenMetadata with only tokenToEndpointMap, i.e., the same as cloneOnlyTokenMap but
uses a cached copy that is invalided when the ring changes, so in the common case
no extra locking is required.
- CachedPartition - Interface in org.apache.cassandra.db.partitions
-
A partition stored in the partition cache.
- CacheKey - Class in org.apache.cassandra.cache
-
- CacheKey(Pair<String, String>) - Constructor for class org.apache.cassandra.cache.CacheKey
-
- cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- cacheKeys() - Method in class org.apache.cassandra.schema.CachingParams
-
- CacheMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ICache
.
- CacheMetrics(String, ICache<?, ?>) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
-
Create metrics for given cache.
- CacheMissMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ICache
.
- CacheMissMetrics(String, CacheSize) - Constructor for class org.apache.cassandra.metrics.CacheMissMetrics
-
Create metrics for given cache.
- CacheProvider<K,V> - Interface in org.apache.cassandra.cache
-
- cacheRows() - Method in class org.apache.cassandra.schema.CachingParams
-
- cacheSerializer - Static variable in interface org.apache.cassandra.db.partitions.CachedPartition
-
- CacheService - Class in org.apache.cassandra.service
-
- cacheService - Variable in class org.apache.cassandra.tools.NodeProbe
-
- CacheService.CacheType - Enum in org.apache.cassandra.service
-
- CacheService.CounterCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
-
- CacheServiceMBean - Interface in org.apache.cassandra.service
-
- CacheSize - Interface in org.apache.cassandra.cache
-
- cacheSize - Static variable in class org.apache.cassandra.cache.ChunkCache
-
- cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- caching(CachingParams) - Method in class org.apache.cassandra.config.CFMetaData
-
- caching(CachingParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- caching - Variable in class org.apache.cassandra.schema.TableParams
-
- cachingFromRow(String) - Static method in class org.apache.cassandra.schema.LegacySchemaMigrator
-
2.1 and newer use JSON'ified map of caching parameters, but older versions had valid Strings
NONE, KEYS_ONLY, ROWS_ONLY, and ALL
- cachingFromThrift(String, String) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- 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
-
- calculateIndexingPageSize() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Return the page size used when indexing an entire partition
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the natural endpoints for the given token
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
calculate endpoints in one pass through the tokens by tracking our progress in each DC.
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- calculatePendingRanges(AbstractReplicationStrategy, String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Calculate pending ranges according to bootsrapping and leaving nodes.
- calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
-
- 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.
- calculateStreamAndFetchRanges(Collection<Range<Token>>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.StorageService
-
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
- callback - Variable in class org.apache.cassandra.net.CallbackInfo
-
- callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- callbackDeserializers - Static variable in class org.apache.cassandra.net.MessagingService
-
A Map of what kind of serializer to wire up to a REQUEST_RESPONSE callback, based on outbound Verb.
- CallbackInfo - Class in org.apache.cassandra.net
-
Encapsulates the callback information.
- CallbackInfo(InetAddress, IAsyncCallback, IVersionedSerializer<?>, boolean) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
Create CallbackInfo without sent message
- callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- calledOnNullInput - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- canBeConvertedToMultiColumnRestriction() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- canBeNonFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- cancel(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the reader from the set we're modifying
- cancel(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the readers from the set we're modifying
- cancel() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Should only be called by the owning thread.
- Candidate(int, Iterator<? extends In>, Comparator<? super In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
-
- canDoLocalRequest(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
-
- 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(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.
- canMinimize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- canMinimize(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- canonicalizeObjectName(String, boolean) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- canSkipValue(ColumnDefinition) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- canSkipValue(CellPath) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- capacity() - Method in interface org.apache.cassandra.cache.CacheSize
-
- capacity() - Method in class org.apache.cassandra.cache.ChunkCache
-
- capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- capacity() - Method in class org.apache.cassandra.cache.SerializingCache
-
- capacity() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- capacity() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Cache capacity in bytes
- capacity - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
Cache capacity in bytes
- capacity() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity in bits (1 greater than the index of the last bit)
- captureWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- cardinality - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
Default cardinality estimation method is to use HyperLogLog++.
- cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- cardinality - Variable in class org.apache.cassandra.utils.TopKSampler.SamplerResult
-
- cardinalityEstimator - Variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- cas(String, String, DecoratedKey, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- cas_contention_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- CASClientRequestMetrics - Class in org.apache.cassandra.metrics
-
- CASClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- casCommit - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Commit metrics
- casCommit - Variable in class org.apache.cassandra.metrics.TableMetrics
-
CAS Commit metrics
- CASE_SENSITIVE - Static variable in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- caseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
-
- caseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
- casPrepare - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Prepare metric
- casPrepare - Variable in class org.apache.cassandra.metrics.TableMetrics
-
CAS Prepare metrics
- casPropose - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Propose metrics
- casPropose - Variable in class org.apache.cassandra.metrics.TableMetrics
-
CAS Propose metrics
- CASRequest - Interface in org.apache.cassandra.service
-
Abstract the conditions and updates for a CAS operation.
- CassandraAuthorizer - Class in org.apache.cassandra.auth
-
CassandraAuthorizer is an IAuthorizer implementation that keeps
user permissions internally in C* using the system_auth.role_permissions
table.
- CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
-
- CassandraDaemon - Class in org.apache.cassandra.service
-
- CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon(boolean) - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon.Server - Interface in org.apache.cassandra.service
-
- CassandraException - Exception in org.apache.cassandra.exceptions
-
- CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- 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
-
- 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.
- 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.
- CassandraRoleManager - Class in org.apache.cassandra.auth
-
Responsible for the creation, maintenance and deletion of roles
for the purposes of authentication and authorization.
- CassandraRoleManager() - Constructor for class org.apache.cassandra.auth.CassandraRoleManager
-
- CassandraServer - Class in org.apache.cassandra.thrift
-
- CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
-
- cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- CassandraVersion - Class in org.apache.cassandra.utils
-
Implements versioning used in Cassandra and CQL.
- CassandraVersion(String) - Constructor for class org.apache.cassandra.utils.CassandraVersion
-
Parse a version from a string.
- 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
- CBCodec<T> - Interface in org.apache.cassandra.transport
-
- CBuilder - Class in org.apache.cassandra.db
-
Allows to build ClusteringPrefixes, either Clustering or ClusteringBound.
- CBuilder() - Constructor for class org.apache.cassandra.db.CBuilder
-
- CBUtil - Class in org.apache.cassandra.transport
-
ByteBuf utility methods.
- cdc(boolean) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- cdc - Variable in class org.apache.cassandra.schema.TableParams
-
- cdc_enabled - Variable in class org.apache.cassandra.config.Config
-
- cdc_free_space_check_interval_ms - Variable in class org.apache.cassandra.config.Config
-
- cdc_raw_directory - Variable in class org.apache.cassandra.config.Config
-
- cdc_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- ceil(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- ceilIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- Cell - Class in org.apache.cassandra.db.rows
-
A cell is our atomic unit for a single value of a single column.
- Cell(ColumnDefinition) - Constructor for class org.apache.cassandra.db.rows.Cell
-
- cellComparator() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- CellGrouper(CFMetaData, SerializationHelper) - Constructor for class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
- cellName - Variable in class org.apache.cassandra.cache.CounterCacheKey
-
- 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.config.ColumnDefinition
-
- cellPathForField(FieldIdentifier) - Method in class org.apache.cassandra.db.marshal.UserType
-
- cellPathSerializer() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- cellPathSerializer - Static variable in class org.apache.cassandra.db.marshal.CollectionType
-
- cells - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyUnfilteredPartition
-
- cells() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- Cells - Class in org.apache.cassandra.db.rows
-
Static methods to work on cells.
- cells() - Method in interface org.apache.cassandra.db.rows.Row
-
An iterable over the cells of this row.
- cellsCount() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- cellsInLegacyOrder(CFMetaData, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- cellsInLegacyOrder(CFMetaData, 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.config.ColumnDefinition
-
The type of the cell values for cell belonging to this column.
- cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
-
- cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
-
- cfamColumns(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfamColumns(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamDefinition(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfamDefinition(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamOrdering(CFProperties) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfamOrdering(CFProperties) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamProperty(CFProperties) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfamProperty(CFProperties) - Method in class org.apache.cassandra.cql3.CqlParser
-
- CfHistograms - Class in org.apache.cassandra.tools.nodetool
-
- CfHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.CfHistograms
-
Deprecated.
- cfId - Variable in class org.apache.cassandra.config.CFMetaData
-
- cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- cfId - Variable in class org.apache.cassandra.streaming.StreamReader
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamTask
-
- cfIds - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- cfisStatic() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfisStatic() - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfm - Variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
The Column Family meta data
- cfm - Variable in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- cfm - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- cfm - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- CFMetaData - Class in org.apache.cassandra.config
-
This class can be tricky to modify.
- CFMetaData.Builder - Class in org.apache.cassandra.config
-
- CFMetaData.DroppedColumn - Class in org.apache.cassandra.config
-
- CFMetaData.Flag - Enum in org.apache.cassandra.config
-
- CFMetaData.Serializer - Class in org.apache.cassandra.config
-
- cfName - Variable in class org.apache.cassandra.config.CFMetaData
-
- CFName - Class in org.apache.cassandra.cql3
-
- CFName() - Constructor for class org.apache.cassandra.cql3.CFName
-
- cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- cfName(CFName) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cfName(CFName) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
-
- cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- CFProperties - Class in org.apache.cassandra.cql3.statements
-
- CFProperties() - Constructor for class org.apache.cassandra.cql3.statements.CFProperties
-
- 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.CompactionController
-
- cfs - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- cfs - Variable in class org.apache.cassandra.db.Memtable
-
- cfs - Variable in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- CFStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that apply on a given column family.
- CFStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.CFStatement
-
- CfStats - Class in org.apache.cassandra.tools.nodetool
-
- CfStats() - Constructor for class org.apache.cassandra.tools.nodetool.CfStats
-
Deprecated.
- cfstore - Variable in class org.apache.cassandra.db.lifecycle.Tracker
-
- chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
-
Construct a chain of resource parents starting with the resource and ending with the root.
- chain(IResource, Predicate<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() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- channel() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- channel - Variable in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- channel - Variable in class org.apache.cassandra.io.util.FileHandle
-
- channel() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- channel - Variable in class org.apache.cassandra.io.util.NIODataInputStream
-
- channel() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
-
- channel() - Method in class org.apache.cassandra.transport.Connection
-
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.cassandra.transport.Message.Dispatcher
-
- ChannelProxy - Class in org.apache.cassandra.io.util
-
A proxy of a FileChannel that:
- implements reference counting
- exports only thread safe FileChannel operations
- wraps IO exceptions into runtime exceptions
Tested by RandomAccessReaderTest.
- ChannelProxy(String) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(File) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(String, FileChannel) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxyReadChannel(ChannelProxy, long) - Constructor for class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- channelRead0(ChannelHandlerContext, Message.Request) - Method in class org.apache.cassandra.transport.Message.Dispatcher
-
- CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- charCount - Variable in class org.apache.cassandra.index.sasi.sa.SA
-
- CHARSET - Static variable in class org.apache.cassandra.io.util.FileUtils
-
- CharTerm - Class in org.apache.cassandra.index.sasi.sa
-
- CharTerm(int, CharBuffer, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.CharTerm
-
- check_for_duplicate_rows_during_compaction - Variable in class org.apache.cassandra.config.Config
-
- check_for_duplicate_rows_during_reads - Variable in class org.apache.cassandra.config.Config
-
If these are enabled duplicate keys will get logged, and if snapshot_on_duplicate_row_detection
is enabled, the table will get snapshotted for offline investigation
- checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform any access verification necessary for the statement.
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterViewStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateViewStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropViewStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- 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()
- checkAvailableDiskSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- checkBindValueSet(ByteBuffer, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified bind marker value is set to a meaningful value.
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- checkComparable() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- checkContainsNoDuplicates(List<?>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified list does not contains duplicates.
- checkContainsOnly(List<E>, List<E>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified list contains only the specified elements.
- checkCrc() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- checkDatacenter - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkDataDirs - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkFalse(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is false
.
- checkFalse(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is false
.
- CheckForAbort() - Constructor for class org.apache.cassandra.db.ReadCommand.CheckForAbort
-
- checkForDuplicateNames(UserType) - Static method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- checkForDuplicateRowsDuringCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- checkForDuplicateRowsDuringReads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- checkForEndpointCollision(UUID, Set<InetAddress>) - Method in class org.apache.cassandra.service.StorageService
-
- checkForExceptions() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- checkForExpiredSSTableBlockers(Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
-
- checkHealth() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
One of three things will happen if you try to read the system keyspace:
1.
- checkIfTupleType(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.Tuples
-
- checkJemalloc - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkJMXPorts - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkJMXProperties - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkLegacyAuthTables - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkLimit(int) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- checkMaxMapCount - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkNativeLibraryInitialization - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkNotNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is NOT null
.
- checkNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is null
.
- checkNull(T, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is null
.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- checkPackageAccess(String) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
-
- checkPermission(ClientState, Permission, RoleResource) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- checkPermission(Permission) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
-
- checkPermission(Permission, Object) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
-
- checkpoint() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
-
- checkpoint() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
call when a consistent batch of changes is ready to be made atomically visible
these will be exposed in the Tracker atomically, or an exception will be thrown; in this case
the transaction should be rolled back
- checkpoint() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- checkpoint() - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- checkpoint() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- checkpw(String, String) - Static method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- checkRack - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkSSTablesFormat - Static variable in class org.apache.cassandra.service.StartupChecks
-
- ChecksummedDataInput - Class in org.apache.cassandra.hints
-
- 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
-
- checksumType - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- ChecksumType - Enum in org.apache.cassandra.utils
-
- checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- ChecksumValidator(ChecksumType, RandomAccessReader, String) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- 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
.
- checkTypeNotUsedByAggregate(KeyspaceMetadata) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- checkUpdateable() - Method in class org.apache.cassandra.db.MultiCBuilder
-
- checkValidLaunchDate - Static variable in class org.apache.cassandra.service.StartupChecks
-
- childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
-
- childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
-
- children - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- chooseGroup(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If the group is empty, use the package name of the given class.
- chooseName(String, Method) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If name is empty, use the name of the given method.
- chooseType(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If the type is empty, use the simple name of the given class.
- Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- CHUNK_LENGTH_IN_KB - Static variable in class org.apache.cassandra.schema.CompressionParams
-
- chunk_length_kb - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.schema.CompressionParams
-
Deprecated.
- CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- CHUNK_SIZE - Static variable in class org.apache.cassandra.utils.memory.BufferPool
-
The size of a page aligned buffer, 64KiB
- ChunkCache - Class in org.apache.cassandra.cache
-
- ChunkCache() - Constructor for class org.apache.cassandra.cache.ChunkCache
-
- 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 - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- chunkSize() - Method in interface org.apache.cassandra.io.util.ChunkReader
-
Buffer size required for this rebufferer.
- chunkSize() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
-
- chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- cident() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- cipher - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- CIPHER_SUITES - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- 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
-
- CLASS - Static variable in class org.apache.cassandra.schema.CompressionParams
-
- CLASS - Static variable in class org.apache.cassandra.schema.ReplicationParams
-
- CLASS - Static variable in class org.apache.cassandra.schema.TriggerMetadata
-
- CLASS_NAME - Static variable in class org.apache.cassandra.config.ParameterizedClass
-
- class_name - Variable in class org.apache.cassandra.config.ParameterizedClass
-
- classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- classOption - Variable in class org.apache.cassandra.schema.TriggerMetadata
-
- clean(ByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- clean() - Method in interface org.apache.cassandra.utils.memory.MemtableCleaner
-
This is a function that schedules a cleaning task, normally flushing of the largest sstable.
- cleanThreshold - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- cleanup() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- Cleanup - Class in org.apache.cassandra.tools.nodetool
-
- Cleanup() - Constructor for class org.apache.cassandra.tools.nodetool.Cleanup
-
- cleanupAfterDeserialize() - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- cleanupAfterDeserialize() - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- CleanupMessage - Class in org.apache.cassandra.repair.messages
-
Message to cleanup repair resources on replica nodes.
- CleanupMessage(UUID) - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage
-
- CleanupMessage.CleanupMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- CleanupMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- 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.
- 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.ConcurrentLinkedHashCache
-
- clear() - Method in interface org.apache.cassandra.cache.ICache
-
- clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- clear() - Method in class org.apache.cassandra.cache.SerializingCache
-
- clear() - Method in class org.apache.cassandra.config.Schema
-
Clear all KS/CF metadata and reset version.
- clear(String) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear(String, Schema) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- clear() - Method in class org.apache.cassandra.db.rows.Row.Merger
-
- clear() - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
-
Clears the current state so that the generator may be reused.
- clear() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- clear() - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- clear() - Method in class org.apache.cassandra.metrics.ClearableHistogram
-
- clear() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- clear() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- clear() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- clear() - Method in class org.apache.cassandra.utils.BloomFilter
-
- clear() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- clear() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- clear() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- clear() - Method in interface org.apache.cassandra.utils.IFilter
-
- clear(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
clears the bit.
- clear() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- clear(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- clear() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- clear(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
clears a bit.
- clear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
clears a bit.
- clear(int, int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Clears a range of bits.
- clear(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Clears a range of bits.
- clear() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- clear_snapshot - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- ClearableHistogram - Class in org.apache.cassandra.metrics
-
Adds ability to reset a histogram
- ClearableHistogram(DecayingEstimatedHistogramReservoir) - Constructor for class org.apache.cassandra.metrics.ClearableHistogram
-
Creates a new Histogram
with the given reservoir.
- clearAllLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Remove all the local of a context (but keep global).
- clearCallbacksUnsafe() - Method in class org.apache.cassandra.net.MessagingService
-
- clearEphemeralSnapshots(Directories) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- clearInternalStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Clear our internal statmeent cache for test purposes.
- clearKeyspaceMetadata(KeyspaceMetadata) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace definition from system
- 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.
- clearMessageSinks() - Method in class org.apache.cassandra.net.MessagingService
-
- clearOverflow() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Resets the count in the overflow bucket to zero.
- clearPreparedStatements(boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Clears the prepared statement cache.
- clearPreparedStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- clearSizeEstimates(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Clears size estimates for a table (on table drop)
- clearSizeEstimates(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Clears size estimates for a keyspace (used to manually clean when we miss a keyspace drop)
- clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Clear all the snapshots for a given column family.
- clearSnapshot(String, List<File>) - Static method in class org.apache.cassandra.db.Directories
-
- clearSnapshot(String, String) - Static method in class org.apache.cassandra.db.Keyspace
-
Clear all the snapshots for a given keyspace.
- clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Remove the snapshot with the given name from the given keyspaces.
- clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Remove the snapshot with the given name from the given keyspaces.
- clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Remove all the existing snapshots.
- ClearSnapshot - Class in org.apache.cassandra.tools.nodetool
-
- ClearSnapshot() - Constructor for class org.apache.cassandra.tools.nodetool.ClearSnapshot
-
- clearSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Clears persisted read rates from system.sstable_activity for SSTables that have been deleted.
- clearState() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Clears any state in this deserializer.
- clearState() - Method in class org.apache.cassandra.db.UnfilteredDeserializer.OldFormatDeserializer
-
- clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
For testing.
- clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
-
used by tests
- clearUnsafe(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
Removes element at the speficied index from this accumulator.
- clearUnwritableUnsafe() - Static method in class org.apache.cassandra.db.DisallowedDirectories
-
Testing only!
Clear the set of unwritable directories.
- Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- Client - Class in org.apache.cassandra.transport
-
- Client(String, int, ProtocolVersion, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
-
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- clientEncOptions - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- ClientEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
-
- clientInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- clientInitialization(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Initializes this class as a client, which means that just an empty configuration will
be used.
- ClientMetrics - Class in org.apache.cassandra.metrics
-
- ClientRequestMetrics - Class in org.apache.cassandra.metrics
-
- ClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
-
- ClientState - Class in org.apache.cassandra.service
-
State related to a client connection.
- ClientState(InetSocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
-
- ClientWarn - Class in org.apache.cassandra.service
-
- ClientWarn.State - Class in org.apache.cassandra.service
-
- clientWarnState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
-
- clock - Variable in class org.apache.cassandra.db.ClockAndCount
-
- Clock - Class 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() - Constructor for class org.apache.cassandra.utils.Clock
-
- ClockAndCount - Class in org.apache.cassandra.db
-
- clone(AbstractAllocator) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- clone() - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
-
Allocate a slice of the given length.
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave operations have finished.
- cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave, and move operations have finished.
- cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with only tokenToEndpointMap.
- cloneWithHigherVersion(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- cloneWithNewPartitioner(IPartitioner) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- cloneWithNewStart(DecoratedKey, Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will
be built at the target samplingLevel.
- cloneWithRestoredStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- cloningBTreeRowBuilder() - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
-
- close() - Method in class org.apache.cassandra.cache.ChunkCache
-
- close() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- close() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- close() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- close() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- close() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- close() - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionPauser
-
- close() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- close() - Method in class org.apache.cassandra.db.compaction.Verifier
-
- close() - Method in class org.apache.cassandra.db.lifecycle.LogReplicaSet
-
- close() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- close() - Method in class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
-
- close() - Method in interface org.apache.cassandra.db.partitions.BasePartitionIterator
-
- close() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
-
- close() - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
-
- close() - Method in class org.apache.cassandra.db.ReadExecutionController
-
- close() - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexInfoRetriever
-
- close() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- close() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- close() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
-
- close() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- close(boolean) - Method in class org.apache.cassandra.db.Slice
-
- close(UnfilteredPartitionIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
-
- close(UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
-
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- close(Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- close() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- close() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
- close() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- close() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
-
- close() - Method in class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
-
- close() - Method in class org.apache.cassandra.index.sasi.plan.Operation
-
- close() - Method in class org.apache.cassandra.index.sasi.TermIterator
-
- close() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- close() - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
-
- close() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.EmptyRangeIterator
-
- close() - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- close(Throwable) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- close() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- close() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- close() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- close() - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
-
- close() - Method in class org.apache.cassandra.io.util.DataInputBuffer
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Closes this stream and frees resources associated with this stream.
- close(Throwable) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
- close() - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
- close(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- close() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- close() - Method in class org.apache.cassandra.io.util.Memory
-
- close() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- close() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
-
- close() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- close(boolean) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- close() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
-
- close() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- close() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- close() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
- close() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- close() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- close() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
-
- close() - Method in class org.apache.cassandra.service.StorageProxy.RangeCommandIterator
-
- close() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- close() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- close() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- close() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Closes the socket.
- close() - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- close() - Method in class org.apache.cassandra.tools.NodeProbe
-
- close() - Method in class org.apache.cassandra.transport.SimpleClient
-
- close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close(Throwable) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close() - Method in interface org.apache.cassandra.utils.CloseableIterator
-
- close() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
To be called exactly once for each register() call this object is returned for, indicating the operation
is complete
- close() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- close() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- close(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- close() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- close(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- close() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- close() - Method in interface org.apache.cassandra.utils.concurrent.Transactional
-
- close() - Method in interface org.apache.cassandra.utils.IFilter
-
- close() - Method in class org.apache.cassandra.utils.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.obs.OpenBitSet
-
- close() - Method in class org.apache.cassandra.utils.RMIClientSocketFactoryImpl
-
- close(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
-
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
-
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- closeAll(Collection<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeBound(boolean) - Method in class 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
-
- closeIncoming() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- 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
-
- closeOutgoing() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- closeQuietly(AutoCloseable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- closeQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- closeQuietly() - Method in class org.apache.cassandra.io.util.MmappedRegions
-
- closeReader() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- closeReader() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- closeReader() - Method in interface org.apache.cassandra.io.util.Rebufferer
-
Called when a reader is closed.
- CloudstackSnitch - Class in org.apache.cassandra.locator
-
A snitch that assumes a Cloudstack Zone follows the typical convention
<country>-<location>-<availability zone> and uses the country/location
tuple as a datacenter and the availability zone as a rack
- CloudstackSnitch() - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
-
- cluster_name - Variable in class org.apache.cassandra.config.Config
-
- Clusterable - Interface in org.apache.cassandra.db
-
Common class for objects that are identified by a clustering prefix, and can be thus sorted by a
ClusteringComparator
.
- clustering() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
-
- clustering() - Method in class org.apache.cassandra.db.AbstractClusteringPrefix
-
- 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 - Interface in org.apache.cassandra.db
-
- clustering() - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
- clustering() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- clustering - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- clustering() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- clustering() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
-
- clustering() - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- clustering - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- clustering() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- clustering() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- clustering() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- clustering() - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
The clustering for the row that is currently being built.
- clustering() - Method in interface org.apache.cassandra.db.rows.Row
-
The clustering values for this row.
- clustering(CFMetaData) - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
-
- Clustering.Serializer - Class in org.apache.cassandra.db
-
Serializer for Clustering object.
- CLUSTERING_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
-
- ClusteringBound - Class in org.apache.cassandra.db
-
The start or end of a range of clusterings, either inclusive or exclusive.
- ClusteringBound(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.ClusteringBound
-
- ClusteringBoundary - Class in org.apache.cassandra.db
-
The threshold between two different ranges, i.e.
- ClusteringBoundary(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.ClusteringBoundary
-
- ClusteringBoundOrBoundary - Class in org.apache.cassandra.db
-
This class defines a threshold between ranges of clusterings.
- ClusteringBoundOrBoundary(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- ClusteringBoundOrBoundary.Serializer - Class in org.apache.cassandra.db
-
- 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() - Method in class org.apache.cassandra.config.CFMetaData
-
- ClusteringComparator - Class in org.apache.cassandra.db
-
A comparator of clustering prefixes (or more generally of
Clusterable
}.
- ClusteringComparator(AbstractType<?>...) - Constructor for class org.apache.cassandra.db.ClusteringComparator
-
- ClusteringComparator(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.ClusteringComparator
-
- clusteringDef(CFMetaData, ByteBuffer, AbstractType<?>, int) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- clusteringDef(String, String, String, AbstractType<?>, int) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- clusteringIndexFilter - Variable in class org.apache.cassandra.db.DataRange
-
- clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.DataRange
-
The clustering index filter to use for the provided key.
- clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- ClusteringIndexFilter - Interface in org.apache.cassandra.db.filter
-
A filter that selects a subset of the rows of a given partition by using the "clustering index".
- clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.ReadCommand
-
The clustering index filter this command to use for the provided key.
- clusteringIndexFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- ClusteringIndexFilter.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.config.ColumnDefinition
-
- ClusteringPrefix - Interface in org.apache.cassandra.db
-
- ClusteringPrefix.Deserializer - Class in org.apache.cassandra.db
-
Helper class that makes the deserialization of clustering prefixes faster.
- ClusteringPrefix.Kind - Enum in org.apache.cassandra.db
-
The kind of clustering prefix this actually is.
- ClusteringPrefix.Serializer - Class in org.apache.cassandra.db
-
- clusteringTypes() - Method in class org.apache.cassandra.db.SerializationHeader
-
- CmdLineOptions() - Constructor for class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
- cmp - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
-
- coalesce(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
Drain from the input blocking queue to the output list up to maxItems elements.
- coalesceInternal(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- CoalescingStrategies - Class in org.apache.cassandra.utils
-
- CoalescingStrategies() - Constructor for class org.apache.cassandra.utils.CoalescingStrategies
-
- CoalescingStrategies.Coalescable - Interface in org.apache.cassandra.utils
-
- CoalescingStrategies.CoalescingStrategy - Class in org.apache.cassandra.utils
-
- CoalescingStrategy(CoalescingStrategies.Parker, Logger, String) - Constructor for class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
-
- code() - Method in exception org.apache.cassandra.exceptions.CassandraException
-
- code - Variable in enum org.apache.cassandra.exceptions.RequestFailureReason
-
The code to be serialized as an unsigned 16 bit integer
- code() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception code.
- code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- code() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- code() - Method in exception org.apache.cassandra.transport.ServerError
-
- codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet
-
- Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- codec - Static variable in enum org.apache.cassandra.transport.DataType
-
- Codec() - Constructor for class org.apache.cassandra.transport.DataType.Codec
-
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthChallenge
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
-
- codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ErrorMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.EventMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.OptionsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.PrepareMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.QueryMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ReadyMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.RegisterMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- codecFor(DataType) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- CollatedViewIndexBuilder - Class in org.apache.cassandra.index.internal
-
Manages building an entire index from column family data.
- CollatedViewIndexBuilder(ColumnFamilyStore, Set<Index>, ReducingKeyIterator) - 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_type() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- collection_type() - Method in class org.apache.cassandra.cql3.CqlParser
-
- COLLECTION_VALUE_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
-
- collectionColumnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw, Term.Raw) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- collectionColumnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw, Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- collectionCondition(Term.Raw, Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
A condition on a collection element.
- collectionElement - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- CollectionEntryIndex - Class in org.apache.cassandra.index.internal.composites
-
Index on the element and value of cells participating in a collection.
- CollectionEntryIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
-
- collectionInCondition(Term.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a collection element.
- collectionInCondition(Term.Raw, AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a collection element with a single marker.
- 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
-
- collectionLiteral() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- collectionLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
-
- collectionName - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyBound
-
- CollectionSerializer<T> - Class in org.apache.cassandra.serializers
-
- CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
-
- collectionSize(List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- collectionSize(List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.MapType
-
- CollectionType<T> - Class in org.apache.cassandra.db.marshal
-
The abstract validator that is the base for maps, sets and lists (both frozen and non-frozen).
- CollectionType(AbstractType.ComparisonType, CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
-
- CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
-
- CollectionValueIndex - Class in org.apache.cassandra.index.internal.composites
-
Index the value of a collection cell.
- CollectionValueIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionValueIndex
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Attributes
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.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.AdderByKey
-
- 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.Maps.SubtracterByKey
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Operation
-
Collects the column specification for the bind variables of this operation.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Term
-
Collects the column specification for the bind variables in this Term.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- Collector() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Collector
-
- collectStats(EncodingStats.Collector) - Method in interface org.apache.cassandra.db.DeletionInfo
-
- collectStats(EncodingStats.Collector) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- collectStats(EncodingStats.Collector) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- collectStats(Cell, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Cells
-
Collect statistics ont a given cell.
- collectStats(Row, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Rows
-
Collect statistics on a given row.
- column - Variable in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- column - Variable in class org.apache.cassandra.cql3.ColumnCondition
-
- column - Variable in class org.apache.cassandra.cql3.Operation
-
- column - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
-
- column - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- column - Variable in class org.apache.cassandra.db.filter.ColumnSubselection
-
- column() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
-
- column - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- column() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- column - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- column() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
-
- column - Variable in class org.apache.cassandra.db.rows.ColumnData
-
- column() - Method in class org.apache.cassandra.db.rows.ColumnData
-
The column this is data for.
- column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- column_index_cache_size_in_kb - Variable in class org.apache.cassandra.config.Config
-
- column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
-
- ColumnCondition - Class in org.apache.cassandra.cql3
-
A CQL3 condition on the value of a column or collection element.
- columnCondition(List<Pair<ColumnDefinition.Raw, ColumnCondition.Raw>>) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- columnCondition(List<Pair<ColumnDefinition.Raw, ColumnCondition.Raw>>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- ColumnCondition.Bound - Class in org.apache.cassandra.cql3
-
- ColumnCondition.CollectionInBound - Class in org.apache.cassandra.cql3
-
- ColumnCondition.Raw - Class in org.apache.cassandra.cql3
-
- ColumnCondition.UDTInBound - Class in org.apache.cassandra.cql3
-
An IN condition on an entire UDT.
- ColumnConditions - Class in org.apache.cassandra.cql3
-
A set of ColumnCondition
s.
- columnConditions() - Method in class org.apache.cassandra.cql3.ColumnConditions
-
- ColumnConditions.Builder - Class in org.apache.cassandra.cql3
-
A Builder
for ColumnConditions
.
- columnCount() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- columnCount() - Method in interface org.apache.cassandra.db.rows.Row
-
The number of columns for which data (incl.
- columnData() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- ColumnData - Class in org.apache.cassandra.db.rows
-
Generic interface for the data of a given column (inside a row).
- ColumnData(ColumnDefinition) - Constructor for class org.apache.cassandra.db.rows.ColumnData
-
- columnData() - Method in interface org.apache.cassandra.db.rows.Row
-
A collection of the ColumnData representation of this row, for columns with some data (possibly not live) present
- columnDef - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
The definition of the column to which apply the restriction.
- ColumnDefinition - Class in org.apache.cassandra.config
-
- ColumnDefinition(CFMetaData, ByteBuffer, AbstractType<?>, int, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition(String, String, ColumnIdentifier, AbstractType<?>, int, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition.ClusteringOrder - Enum in org.apache.cassandra.config
-
- ColumnDefinition.Kind - Enum in org.apache.cassandra.config
-
- ColumnDefinition.Raw - Class in org.apache.cassandra.config
-
Because Thrift-created tables may have a non-text comparator, we cannot determine the proper 'key' until
we know the comparator.
- columnDefinitionComparator(String, boolean, AbstractType<?>, AbstractType<?>) - Static method in class org.apache.cassandra.db.CompactTables
-
- 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(ColumnDefinition.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ColumnDeletion
-
- columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- COLUMNFAMILIES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
-
- columnFamily - Variable in class org.apache.cassandra.db.Truncation
-
- columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
- columnFamilyName() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- columnFamilyName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- ColumnFamilySplit - Class in org.apache.cassandra.hadoop
-
- ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
Deprecated.
- ColumnFamilySplit(String, String, long, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilyStore - Class in org.apache.cassandra.db
-
- ColumnFamilyStore(Keyspace, String, int, CFMetaData, Directories, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
-
- ColumnFamilyStore.RefViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStoreCQLHelper - Class in org.apache.cassandra.db
-
Helper methods to represent CFMetadata and related objects in CQL format
- ColumnFamilyStoreCQLHelper() - Constructor for class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
- ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
-
The MBean interface for ColumnFamilyStore
- ColumnFilter - Class in org.apache.cassandra.db.filter
-
Represents which (non-PK) columns (and optionally which sub-part of a column for complex columns) are selected
by a query.
- columnFilter() - Method in class org.apache.cassandra.db.ReadCommand
-
A filter on which (non-PK) columns must be returned by the query.
- ColumnFilter.Builder - Class in org.apache.cassandra.db.filter
-
A builder for a ColumnFilter
object.
- ColumnFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- ColumnFilter.Tester - Class in org.apache.cassandra.db.filter
-
- ColumnIdentifier - Class in org.apache.cassandra.cql3
-
Represents an identifer for a CQL column definition.
- ColumnIdentifier(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier(ByteBuffer, String) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIndex - Class in org.apache.cassandra.db
-
- ColumnIndex(SerializationHeader, SequentialWriter, Version, Collection<SSTableFlushObserver>, ISerializer<IndexInfo>) - Constructor for class org.apache.cassandra.db.ColumnIndex
-
- ColumnIndex - Class in org.apache.cassandra.index.sasi.conf
-
- ColumnIndex(AbstractType<?>, ColumnDefinition, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- columnIndex - Variable in class org.apache.cassandra.index.sasi.memory.MemIndex
-
- columnIndexCount - Variable in class org.apache.cassandra.db.ColumnIndex
-
- columnName(List<String>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- columnName(List<String>) - Method in interface org.apache.cassandra.cql3.functions.Function
-
Returns the name of the function to use within a ResultSet.
- columnName - Variable in exception org.apache.cassandra.db.UnknownColumnException
-
- columnNameGenerator(List<ColumnDefinition>, List<ColumnDefinition>, PartitionColumns) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
Create a column name generator for SuperColumns
- columnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- columnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- columnOperationDifferentiator(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- columnOperationDifferentiator(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- columns - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- columns(String...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- columns - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- columns() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- Columns - Class in org.apache.cassandra.db
-
An immutable and sorted list of (non-PK) columns for a given table.
- columns(boolean) - Method in class org.apache.cassandra.db.PartitionColumns
-
- 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
-
- columns - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- columns() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- columns() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
-
A subset of the columns for the (static and regular) rows returned by this iterator.
- columns() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- columns() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- columns() - Method in interface org.apache.cassandra.db.rows.Row
-
An in-natural-order collection of the columns for which data (incl.
- columns() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
-
- columns() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- columns() - Method in class org.apache.cassandra.db.SerializationHeader
-
- columns(boolean) - Method in class org.apache.cassandra.db.SerializationHeader
-
- columns() - Method in class org.apache.cassandra.db.transform.BaseRows
-
- columns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- columns() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- Columns.Serializer - Class in org.apache.cassandra.db
-
- columnsIndex(int) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexInfoRetriever
-
- columnsIndexCount() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- ColumnSpecification - Class in org.apache.cassandra.cql3
-
- ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
-
- ColumnSubselection - Class in org.apache.cassandra.db.filter
-
Handles the selection of a subpart of a column.
- ColumnSubselection(ColumnDefinition) - Constructor for class org.apache.cassandra.db.filter.ColumnSubselection
-
- ColumnSubselection.Serializer - Class in org.apache.cassandra.db.filter
-
- ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
-
- colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Column update time delta on this Keyspace
- colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Column update time delta on this CF
- combinedIndex - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- CombinedTerm - Class in org.apache.cassandra.index.sasi.utils
-
- CombinedTerm(AbstractType<?>, OnDiskIndex.DataTerm) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- CombinedTermIterator - Class in org.apache.cassandra.index.sasi.utils
-
- CombinedTermIterator(OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
-
- CombinedTermIterator(Descriptor, OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
-
- CombinedValue<V> - Interface in org.apache.cassandra.index.sasi.utils
-
- command - Variable in class org.apache.cassandra.index.internal.CassandraIndexSearcher
-
- command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- command - Variable in class org.apache.cassandra.service.ResponseResolver
-
- commands - Variable in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- comment(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- comment(String) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- comment - Variable in class org.apache.cassandra.schema.TableParams
-
- commit() - Method in class org.apache.cassandra.auth.CassandraLoginModule
-
This method is called if the LoginContext's overall authentication succeeded
(the relevant REQUIRED, REQUISITE, SUFFICIENT and OPTIONAL LoginModules
succeeded).
- commit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- commit() - Method in interface org.apache.cassandra.index.transactions.IndexTransaction
-
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- commit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- Commit - Class in org.apache.cassandra.service.paxos
-
- Commit(UUID, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit
-
- commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- commit() - Method in interface org.apache.cassandra.utils.BatchRemoveIterator
-
Commits the remove operations in this batch iterator.
- commit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
commit any effects of this transaction object graph, then cleanup; delegates first to doCommit, then to doCleanup
- commit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- commit(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
-
- Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
-
- commit_failure_policy - Variable in class org.apache.cassandra.config.Config
-
- commitLog - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
- CommitLog - Class in org.apache.cassandra.db.commitlog
-
- CommitLog.Configuration - Class in org.apache.cassandra.db.commitlog
-
- commitlog_compression - Variable in class org.apache.cassandra.config.Config
-
- commitlog_directory - Variable in class org.apache.cassandra.config.Config
-
- commitlog_max_compression_buffers_in_pool - Variable in class org.apache.cassandra.config.Config
-
- commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- commitlog_segment_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
-
- CommitLogArchiver(String, String, String, long, TimeUnit) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
-
- CommitLogDescriptor(int, long, ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogDescriptor(long, ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- commitLogIntervals - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogIntervals(IntervalSet<CommitLogPosition>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogIntervals - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogMetrics - Class in org.apache.cassandra.metrics
-
Metrics for commit log
- CommitLogMetrics() - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
-
- CommitLogPosition - Class in org.apache.cassandra.db.commitlog
-
Contains a segment id and a position for CommitLogSegment identification.
- CommitLogPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- CommitLogPosition.CommitLogPositionSerializer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
-
- commitLogPositionSetSerializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- CommitLogReader - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReader() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReader
-
- commitLogReader - Variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- CommitLogReadHandler - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogReadHandler.CommitLogReadErrorReason - Enum in org.apache.cassandra.db.commitlog
-
- CommitLogReadHandler.CommitLogReadException - Exception in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer.CommitLogReplayException - Exception in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer.MutationInitiator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayException(String, Throwable) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
-
- CommitLogReplayException(String) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
-
- CommitLogSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.Allocation - Class in org.apache.cassandra.db.commitlog
-
A simple class for tracking information about the portion of a segment that has been allocated to a log write.
- CommitLogSegment.CDCState - Enum in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- CommitLogSegmentManagerCDC - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentManagerCDC(CommitLog, String) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
- CommitLogSegmentManagerStandard - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentManagerStandard(CommitLog, String) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
-
- CommitLogSegmentReader - Class in org.apache.cassandra.db.commitlog
-
Read each sync section of a commit log, iteratively.
- CommitLogSegmentReader(CommitLogReadHandler, CommitLogDescriptor, RandomAccessReader, boolean) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentReader
-
- CommitLogSegmentReader.SegmentIterator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentReader.SegmentReadException - Exception in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentReader.SyncSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- CommitVerbHandler - Class in org.apache.cassandra.service.paxos
-
- CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- Compact - Class in org.apache.cassandra.tools.nodetool
-
- Compact() - Constructor for class org.apache.cassandra.tools.nodetool.Compact
-
- compactedPartitionMaximumBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- compactedPartitionMeanBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- compactedPartitionMinimumBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
-
- CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- compactingRepaired() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- compaction(CompactionParams) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.TableParams.Builder
-
- compaction - Variable in class org.apache.cassandra.schema.TableParams
-
- COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- COMPACTION_HISTORY - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- compaction_large_partition_warning_threshold_mb - Variable in class org.apache.cassandra.config.Config
-
- compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
-
- COMPACTION_WINDOW_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- COMPACTION_WINDOW_UNIT_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- CompactionAwareWriter - Class in org.apache.cassandra.db.compaction.writers
-
Class that abstracts away the actual writing of files to make it possible to use CompactionTask for more
use cases.
- CompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Deprecated.
- CompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- compactionBytesWritten - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total number of bytes written by compaction since server [re]start
- CompactionCandidate(Collection<SSTableReader>, int, long) - Constructor for class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- CompactionController - Class in org.apache.cassandra.db.compaction
-
Manage compaction options.
- CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, int, RateLimiter, CompactionParams.TombstoneOption) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- compactionDiskSpaceCheck(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- compactionDiskSpaceCheck(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- CompactionHistory - Class in org.apache.cassandra.tools.nodetool
-
- CompactionHistory() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionHistory
-
- CompactionHistoryHolder - Class in org.apache.cassandra.tools.nodetool.stats
-
- CompactionHistoryHolder(NodeProbe) - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
-
- CompactionHistoryPrinter - Class in org.apache.cassandra.tools.nodetool.stats
-
- CompactionHistoryPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter
-
- CompactionHistoryPrinter.DefaultPrinter - Class in org.apache.cassandra.tools.nodetool.stats
-
- CompactionHistoryTabularData - Class in org.apache.cassandra.db.compaction
-
- CompactionHistoryTabularData() - Constructor for class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- compactionId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo - Class in org.apache.cassandra.db.compaction
-
Implements serializable to allow structured info to be returned via JMX.
- CompactionInfo(CFMetaData, OperationType, long, long, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(OperationType, long, long, CompactionInfo.Unit, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(CFMetaData, OperationType, long, long, CompactionInfo.Unit, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
-
- CompactionInfo.Unit - Enum in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException - Exception in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException(CompactionInfo) - Constructor for exception org.apache.cassandra.db.compaction.CompactionInterruptedException
-
- CompactionIterator - Class in org.apache.cassandra.db.compaction
-
Merge multiple iterators over the content of sstable into a "compacted" iterator.
- CompactionIterator(OperationType, List<ISSTableScanner>, CompactionController, int, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
-
- CompactionIterator(OperationType, List<ISSTableScanner>, CompactionController, int, UUID, CompactionMetrics) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
-
- CompactionLogger - Class in org.apache.cassandra.db.compaction
-
- CompactionLogger(ColumnFamilyStore, CompactionStrategyManager) - Constructor for class org.apache.cassandra.db.compaction.CompactionLogger
-
- compactionLogger - Variable in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- CompactionLogger.Strategy - Interface in org.apache.cassandra.db.compaction
-
- CompactionLogger.StrategySummary - Interface in org.apache.cassandra.db.compaction
-
This will produce the compaction strategy's starting information.
- CompactionLogger.Writer - Interface in org.apache.cassandra.db.compaction
-
This is an interface to allow writing to a different interface.
- CompactionManager - Class in org.apache.cassandra.db.compaction
-
A singleton which manages a private executor of ongoing compactions.
- CompactionManager() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager
-
- CompactionManager.AllSSTableOpStatus - Enum in org.apache.cassandra.db.compaction
-
- CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
-
- CompactionManager.CompactionPauser - Interface in org.apache.cassandra.db.compaction
-
- CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
-
- CompactionMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
Compaction related SSTable metadata.
- CompactionMetadata(ICardinality) - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- CompactionMetadata.CompactionMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
- CompactionMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- CompactionMetrics - Class in org.apache.cassandra.metrics
-
Metrics for compaction.
- CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
-
- CompactionParams - Class in org.apache.cassandra.schema
-
- CompactionParams.Option - Enum in org.apache.cassandra.schema
-
- CompactionParams.TombstoneOption - Enum in org.apache.cassandra.schema
-
- compactionProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- CompactionStats - Class in org.apache.cassandra.tools.nodetool
-
- CompactionStats() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionStats
-
- compactionStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- CompactionStrategyManager - Class in org.apache.cassandra.db.compaction
-
Manages the compaction strategies.
- CompactionStrategyManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- CompactionStrategyManager(ColumnFamilyStore, Supplier<DiskBoundaries>, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- CompactionTask - Class in org.apache.cassandra.db.compaction
-
- CompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
- CompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
Deprecated.
- CompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
- 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
-
- CompactTables - Class in org.apache.cassandra.db
-
Small utility methods pertaining to the encoding of COMPACT STORAGE tables.
- CompactTables.DefaultNames - Class in org.apache.cassandra.db
-
- compactValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- comparator - Variable in class org.apache.cassandra.config.CFMetaData
-
- comparator() - Method in class org.apache.cassandra.db.CBuilder
-
- comparator - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
-
- comparator - Variable in class org.apache.cassandra.db.MultiCBuilder
-
The table comparator.
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- comparator - Static variable in class org.apache.cassandra.db.rows.Cell
-
- comparator - Static variable in class org.apache.cassandra.db.rows.ColumnData
-
- comparator - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- comparator - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
-
- comparator - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- comparator - Variable in class org.apache.cassandra.index.sasi.sa.SA
-
- comparator() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
-
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- comparator - Variable in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparatorType() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
-
- compare(Clusterable, Clusterable) - Method in class org.apache.cassandra.db.ClusteringComparator
-
- compare(ClusteringPrefix, ClusteringPrefix) - Method in class org.apache.cassandra.db.ClusteringComparator
-
- compare(Clustering, Clustering) - Method in class org.apache.cassandra.db.ClusteringComparator
-
- compare(Clustering, Clustering, int) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Compares the specified part of the specified clusterings.
- compare(ClusteringPrefix.Kind, ClusteringPrefix.Kind) - Static method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
Compares the 2 provided kind.
- compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compare(long, long) - Method in interface org.apache.cassandra.utils.LongTimSort.LongComparator
-
- compareAsymmetric(T1, T2) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
-
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compareComponent(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.ClusteringComparator
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Implement IFF ComparisonType is CUSTOM
Compares the ByteBuffer 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(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ListType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.MapType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SetType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- compareCustom(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- comparedToClustering - Variable in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
Return the comparison of this kind to CLUSTERING.
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
determine which endpoint started up earlier
- 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(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.IntegerType
-
- compareLongs(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.LongType
-
- compareMaps(AbstractType<?>, AbstractType<?>, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- compareNextTo(ClusteringBoundOrBoundary) - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
-
- compareNextTo(ClusteringBound) - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Compare the provided bound to the next atom to read on disk.
- compareNextTo(ClusteringBound) - Method in class org.apache.cassandra.db.UnfilteredDeserializer.OldFormatDeserializer
-
- comparePageTo(long, int, AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- compareResponses() - Method in class org.apache.cassandra.service.DataResolver
-
- compareResponses() - Method in class org.apache.cassandra.service.DigestResolver
-
- compareResponses() - Method in class org.apache.cassandra.service.ResponseResolver
-
Compares received responses, potentially triggering a digest mismatch (for a digest resolver) and read-repairs
(for a data resolver).
- compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Compare two ByteBuffer at specified offsets for length.
- compareTo(FunctionResource) - Method in class org.apache.cassandra.auth.FunctionResource
-
- compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
-
- compareTo(RoleResource) - Method in class org.apache.cassandra.auth.RoleResource
-
- compareTo(ColumnDefinition) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- compareTo(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- compareTo(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- compareTo(PartitionPosition) - Method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(IPartitioner, ByteBuffer, PartitionPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- compareTo(ColumnSubselection) - Method in class org.apache.cassandra.db.filter.ColumnSubselection
-
- compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Note: this class has a natural ordering that is inconsistent with equals
- compareTo(PartitionPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
-
- compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
-
- compareTo(RangeTermTree.Term) - Method in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree.Term
-
- compareTo(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
-
- compareTo(CombinedValue<Long>) - Method in class org.apache.cassandra.index.sasi.disk.Token
-
- compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
-
- compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
-
- compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.Term
-
- compareTo(AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.Term
-
- compareTo(AbstractType<?>, ByteBuffer, boolean) - Method in class org.apache.cassandra.index.sasi.Term
-
- compareTo(CombinedValue<OnDiskIndex.DataTerm>) - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- compareTo(MetadataComponent) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
-
- compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- compareTo(InetAddressAndPort) - Method in class org.apache.cassandra.locator.InetAddressAndPort
-
- compareTo(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- compareTo(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
-
- compareTo(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- compareTo(CounterId) - Method in class org.apache.cassandra.utils.CounterId
-
- compareTo(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compareTo(Object, long, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compareTo(Object, long, int, Object, long, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
Lexicographically compare two arrays.
- compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compareUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
Lexicographically compare two byte arrays.
- compareUnsigned(ByteBuffer, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(byte[], int, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compareWithOperator(Operator, AbstractType<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
Returns true if the operator is satisfied (i.e.
- comparisonPath() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
-
- comparisonType - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- compile(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- complete() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- complete() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- complete() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
-
- complete(CountDownLatch) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- complete() - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
-
- complete() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
-
Called when all data is written to the file and it's ready to be finished up.
- complete() - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Complete building
FileHandle
without overriding file length.
- complete(long) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Complete building
FileHandle
with the given length, which overrides the file length.
- complete() - Method in class org.apache.cassandra.repair.Validator
-
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
- complete() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- complete() - Method in class org.apache.cassandra.streaming.StreamSession
-
Check if session is completed on receiving StreamMessage.Type.COMPLETE
message.
- complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for file at sequenceNumber
.
- completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Number of completed tasks
- completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Number of completed compactions since server [re]start
- completedTasks - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of completed tasks.
- completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of completed tasks.
- CompleteMessage - Class in org.apache.cassandra.streaming.messages
-
- CompleteMessage() - Constructor for class org.apache.cassandra.streaming.messages.CompleteMessage
-
- completeSetup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- completeTree() - Method in class org.apache.cassandra.repair.Validator
-
- 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(ColumnDefinition) - Method in class org.apache.cassandra.db.Columns
-
The index of the provided complex column in this object (if it contains
the provided column).
- Component - Class in org.apache.cassandra.io.sstable
-
SSTables are made up of multiple components in separate files.
- Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component(Component.Type, String) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component.Type - Enum in org.apache.cassandra.io.sstable
-
- componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- components - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- componentsCount() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
The number of subcomponents this type has.
- componentsCount() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- componentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Discovers existing components for the descriptor.
- componentSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.Tuples
-
- compose(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
Used by UDF implementations (both Java code generated by
JavaBasedUDFunction
and script executor
ScriptBasedUDFunction
) to convert the C*
serialized representation to the Java object representation.
- compose(TypeCodec<Object>[], ProtocolVersion, int, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- compose_boolean(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_byte(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_double(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_float(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_int(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_long(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- compose_short(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- CompositesSearcher - Class in org.apache.cassandra.index.internal.composites
-
- CompositesSearcher(ReadCommand, RowFilter.Expression, CassandraIndex) - Constructor for class org.apache.cassandra.index.internal.composites.CompositesSearcher
-
- CompositeType - Class in org.apache.cassandra.db.marshal
-
- CompositeType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.CompositeType
-
- CompositeType.Builder - Class in org.apache.cassandra.db.marshal
-
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
Compression for ByteBuffers.
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- compress(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(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- compressArray(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compressed(boolean) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
- COMPRESSED_BLOCK_HEADER_SIZE - Static variable in class org.apache.cassandra.security.EncryptionUtils
-
- CompressedChecksummedDataInput - Class in org.apache.cassandra.hints
-
- CompressedChecksummedDataInput(ChannelProxy, ICompressor, long) - Constructor for class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
- compressedChecksumType() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- CompressedChunkReader - Class in org.apache.cassandra.io.util
-
- CompressedChunkReader(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader
-
- CompressedChunkReader.Mmap - Class in org.apache.cassandra.io.util
-
- CompressedChunkReader.Standard - Class in org.apache.cassandra.io.util
-
- compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
-
- CompressedHintsWriter - Class in org.apache.cassandra.hints
-
- CompressedHintsWriter(File, HintsDescriptor, File, FileChannel, int, CRC32) - Constructor for class org.apache.cassandra.hints.CompressedHintsWriter
-
- CompressedInputStream - Class in org.apache.cassandra.streaming.compress
-
InputStream which reads data from underlining source with given
CompressionInfo
.
- CompressedInputStream(InputStream, CompressionInfo, ChecksumType, Supplier<Double>) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- CompressedSegment - Class in org.apache.cassandra.db.commitlog
-
Compressed commit log segment.
- CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
-
- CompressedSequentialWriter(File, String, File, SequentialWriterOption, CompressionParams, MetadataCollector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
Create CompressedSequentialWriter without digest file.
- CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
-
Class to hold a mark to the position of the file
- CompressedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.compress
-
- CompressedStreamReader - Class in org.apache.cassandra.streaming.compress
-
StreamReader that reads from streamed compressed SSTable
- CompressedStreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressedStreamWriter - Class in org.apache.cassandra.streaming.compress
-
StreamWriter for compressed SSTable.
- CompressedStreamWriter(SSTableReader, Collection<Pair<Long, Long>>, CompressionInfo, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- compression(CompressionParams) - Method in class org.apache.cassandra.config.CFMetaData
-
- compression - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- compression(CompressionParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- compression - Variable in class org.apache.cassandra.schema.TableParams
-
- COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressionInfo - Class in org.apache.cassandra.streaming.compress
-
Container that carries compression parameters and chunks to decompress data from stream.
- CompressionInfo(CompressionMetadata.Chunk[], CompressionParams) - Constructor for class org.apache.cassandra.streaming.compress.CompressionInfo
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
Compression info for SSTable to send.
- CompressionMetadata - Class in org.apache.cassandra.io.compress
-
Holds metadata about compressed file
- CompressionMetadata(String, long, ChecksumType) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata
-
- compressionMetadata() - Method in class org.apache.cassandra.io.util.FileHandle
-
- CompressionMetadata.Chunk - Class in org.apache.cassandra.io.compress
-
Holds offset and length of the file chunk
- CompressionMetadata.Writer - Class in org.apache.cassandra.io.compress
-
- compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Off heap memory used by compression meta data
- compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Off heap memory used by compression meta data
- compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- compressionMetadataOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- compressionParametersToThrift(CompressionParams) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- compressionParams() - Method in class org.apache.cassandra.config.CFMetaData
-
- CompressionParams - Class in org.apache.cassandra.schema
-
- CompressionParams(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.schema.CompressionParams
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- compressionRatio - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Current compression ratio for all SSTables
- compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- Compressor() - Constructor for class org.apache.cassandra.transport.Frame.Compressor
-
- compute(ProtocolVersion) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Computes and returns the aggregate current value.
- compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- computeBloomSpec(int) - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Given the number of buckets that can be used per element, return a
specification that minimizes the false positive rate.
- computeBloomSpec(int, double) - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Given a maximum tolerable false positive probability, compute a Bloom
specification which will give less than the specified false positive rate,
but minimize the number of buckets per element and the number of hash
functions used.
- computeConcurrencyFactor(int, int, int, int, int) - Static method in class org.apache.cassandra.service.StorageProxy.RangeCommandIterator
-
- computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
-
- computeLocalExpirationTime(int, int) - Static method in class org.apache.cassandra.db.ExpirationDateOverflowHandling
-
- computeNext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentIterator
-
- computeNext() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition.SlicesIterator
-
- 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.UnfilteredRowIteratorWithLowerBound
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.LevelIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.plan.Operation
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.TermIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
-
Returns the next element.
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.BounceIntersectionIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.LookupIntersectionIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.EmptyRangeIterator
-
- computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.KeyScanningIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- computeNext() - Method in class org.apache.cassandra.service.StorageProxy.RangeCommandIterator
-
- computeNext() - Method in class org.apache.cassandra.service.StorageProxy.RangeIterator
-
- computeNext() - Method in class org.apache.cassandra.service.StorageProxy.RangeMerger
-
- 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
-
- computeSubPageSize(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
-
- computeSubPageSize(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
-
Computes the size of the next sub-page to retrieve.
- computeUnsignedVIntSize(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Compute the number of bytes that would be needed to encode an unsigned varint.
- computeVIntSize(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Compute the number of bytes that would be needed to encode a varint.
- concat(List<PartitionIterator>) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
-
- concat(List<UnfilteredPartitionIterator>) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
-
- concat(UnfilteredRowIterator, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that concatenate two atom iterators.
- concat(Unfiltered, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that concatenate the specified atom with the iterator.
- concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- Concurrent(long) - Constructor for class org.apache.cassandra.net.ResourceLimits.Concurrent
-
- concurrent_compactors - Variable in class org.apache.cassandra.config.Config
-
- concurrent_counter_writes - Variable in class org.apache.cassandra.config.Config
-
- concurrent_materialized_view_writes - Variable in class org.apache.cassandra.config.Config
-
- concurrent_reads - Variable in class org.apache.cassandra.config.Config
-
- concurrent_replicates - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- concurrent_writes - Variable in class org.apache.cassandra.config.Config
-
- ConcurrentBiMap<K,V> - Class in org.apache.cassandra.utils
-
A variant of BiMap that permits concurrent access, and expects uniqueness of values in both domain and range.
- ConcurrentBiMap() - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
-
- ConcurrentBiMap(Map<K, V>, Map<V, K>) - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
-
- ConcurrentLinkedHashCache<K extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
-
Wrapper so CLHM can implement ICache interface.
- condition(ColumnDefinition, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- condition(ColumnDefinition, Term, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- condition(ColumnDefinition, FieldIdentifier, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- conditionColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- conditionNotMet - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- Conditions - Interface in org.apache.cassandra.cql3
-
Conditions that can be applied to a mutation statement.
- conf - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- Config - Class in org.apache.cassandra.config
-
A class that contains configuration properties for the cassandra node it runs within.
- Config() - Constructor for class org.apache.cassandra.config.Config
-
- Config.CommitFailurePolicy - Enum in org.apache.cassandra.config
-
- Config.CommitLogSync - Enum in org.apache.cassandra.config
-
- Config.DiskAccessMode - Enum in org.apache.cassandra.config
-
- Config.DiskFailurePolicy - Enum in org.apache.cassandra.config
-
- Config.DiskOptimizationStrategy - Enum in org.apache.cassandra.config
-
- Config.InternodeCompression - Enum in org.apache.cassandra.config
-
- Config.MemtableAllocationType - Enum in org.apache.cassandra.config
-
- Config.RequestSchedulerId - Enum in org.apache.cassandra.config
-
- Config.UserFunctionTimeoutPolicy - Enum in org.apache.cassandra.config
-
- CONFIG_PATH - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- ConfigHelper - Class in org.apache.cassandra.hadoop
-
- ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
-
- configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- Configuration(ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
- ConfigurationException - Exception in org.apache.cassandra.exceptions
-
- ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, boolean) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationLoader - Interface in org.apache.cassandra.config
-
- ConfiguredLimit - Class in org.apache.cassandra.transport
-
- ConfiguredLimit() - Constructor for class org.apache.cassandra.transport.ConfiguredLimit
-
- confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- Conflicts - Class in org.apache.cassandra.db
-
- Conflicts.Resolution - Enum in org.apache.cassandra.db
-
- connect(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- connect() - Method in class org.apache.cassandra.tools.NodeProbe
-
Create a connection to the JMX agent and setup the M[X]Bean proxies.
- connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- connect(boolean, boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- connecting - Variable in class org.apache.cassandra.streaming.SessionInfo
-
- connecting - Variable in class org.apache.cassandra.streaming.StreamSession
-
Actual connecting address.
- Connection - Class in org.apache.cassandra.transport
-
- Connection(Channel, ProtocolVersion, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
-
- connection - Variable in class org.apache.cassandra.transport.Message
-
- connection() - Method in class org.apache.cassandra.transport.Message
-
- connection - Variable in class org.apache.cassandra.transport.SimpleClient
-
- Connection.Factory - Interface in org.apache.cassandra.transport
-
- Connection.Tracker - Interface in org.apache.cassandra.transport
-
- connectionComplete(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
The connection associated with @param socket is permanently finished.
- connectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Set custom StreamConnectionFactory to be used for establishing connection
- ConnectionHandler - Class in org.apache.cassandra.streaming
-
ConnectionHandler manages incoming/outgoing message exchange for the
StreamSession
.
- ConnectionMetrics - Class in org.apache.cassandra.metrics
-
- ConnectionMetrics(InetAddress, OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.metrics.ConnectionMetrics
-
Create metrics for given connection pool.
- connections - Variable in class org.apache.cassandra.net.MessagingService.SocketThread
-
- CONNECTIONS_PER_HOST - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- connectionsPerHost - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
-
- connector - Variable in class org.apache.cassandra.locator.Ec2Snitch
-
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- consistency - Variable in class org.apache.cassandra.service.ResponseResolver
-
- consistencyForRole(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
-
- ConsistencyLevel - Enum in org.apache.cassandra.db
-
- consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- CONSOLE - Static variable in class org.apache.cassandra.tools.Output
-
- constant() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- constant() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Constants - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for constants.
- Constants() - Constructor for class org.apache.cassandra.cql3.Constants
-
- Constants.Adder - Class in org.apache.cassandra.cql3
-
- Constants.Deleter - Class in org.apache.cassandra.cql3
-
- Constants.Literal - Class in org.apache.cassandra.cql3
-
- Constants.Marker - Class in org.apache.cassandra.cql3
-
- Constants.Setter - Class in org.apache.cassandra.cql3
-
- Constants.Substracter - Class in org.apache.cassandra.cql3
-
- Constants.Type - Enum in org.apache.cassandra.cql3
-
- Constants.Value - Class in org.apache.cassandra.cql3
-
A constant value, i.e.
- construct() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- construct(CommitLog, UUID) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- construct(ColumnFamilyStore, ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Constructs an instance of the given class, which must have a no-arg or default constructor.
- constructionTime() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- constructionTime() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- constructionTime - Variable in class org.apache.cassandra.net.MessageIn
-
- constructKeepingOriginals(ILifecycleTransaction, boolean, long, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
Deprecated.
- constructKeepingOriginals(ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- constructTree() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- constructTree() - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- constructTree() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- constructWithoutEarlyOpening(ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- consume(PartitionIterator) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
-
- consume(MergeIterator.Reducer) - 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.
- contains(ColumnDefinition) - Method in class org.apache.cassandra.db.Columns
-
Whether the provided column is contained by this object.
- contains(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Check to see if a certain CommitLogPosition is contained by this segment file.
- contains(T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet
-
- contains(PartitionPosition) - Method in class org.apache.cassandra.db.DataRange
-
Whether the provided ring position is covered by this DataRange
.
- contains(ColumnDefinition) - Method in class org.apache.cassandra.db.PartitionColumns
-
- contains(String) - Method in class org.apache.cassandra.db.view.TableViews
-
- contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.Bounds
-
- contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
-
- contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- contains(T) - Method in class org.apache.cassandra.dht.Range
-
Helps determine if a given point on the DHT ring is contained
in the range in question.
- contains(Token) - Method in class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
-
Returns true if the ranges given in the constructor contains the token, false otherwise.
- contains(String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
- contains(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- contains(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Check is the given buffer contains a given sub-buffer.
- containsAComplexColumn() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains a complex column.
- 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
-
- containsApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- containsBindMarker() - Method in interface org.apache.cassandra.cql3.Term
-
Whether or not that term contains at least one bind marker.
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- containsCachedParition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- containsCustomExpressions() - Method in class org.apache.cassandra.cql3.WhereClause
-
- containsFailureReason() - Method in class org.apache.cassandra.net.MessageIn
-
- containsKey(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- containsKey(K) - Method in interface org.apache.cassandra.cache.ICache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- containsNull - Variable in class org.apache.cassandra.db.MultiCBuilder
-
true
if the clusterings contains some null
elements.
- containsNull() - Method in class org.apache.cassandra.db.MultiCBuilder
-
Checks if the clusterings contains null elements.
- containsOnlyStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains only static columns.
- ContainsRestriction(ColumnDefinition, Term, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- ContainsRestriction(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- containsSstableCompressionClass(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
-
Returns true
if the specified options contains the name of the compression class to be used,
false
otherwise.
- containsStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains static columns.
- containsTokenRelations() - Method in class org.apache.cassandra.cql3.WhereClause
-
Checks if the where clause contains some token relations.
- containsUnset - Variable in class org.apache.cassandra.db.MultiCBuilder
-
true
if the composites contains some unset
elements.
- containsUnset() - Method in class org.apache.cassandra.db.MultiCBuilder
-
Checks if the clusterings contains unset elements.
- containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsValue(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- content - Variable in class org.apache.cassandra.index.sasi.Term
-
- contention - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- contentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- context - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- ContextAllocator - Class in org.apache.cassandra.utils.memory
-
Wraps calls to a PoolAllocator with the provided writeOp.
- ContextAllocator(OpOrder.Group, MemtableBufferAllocator) - Constructor for class org.apache.cassandra.utils.memory.ContextAllocator
-
- convert(long) - Static method in class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
-
- convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
-
- convert2Map() - Method in interface org.apache.cassandra.tools.nodetool.stats.StatsHolder
-
- convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
-
- convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.TpStatsHolder
-
- convertForMessagingServiceVersion(MessagingService.Verb, int) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
- convertPropertyMap(Maps.Literal) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- convertSchemaToMutations() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is part of IFailureDetectionEventListener interface.
- convict(InetAddress, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
-
Convict the specified endpoint.
- convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
called from gossiper when it notices a node is not responding.
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.AnticompactionTask
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.RepairSession
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Something has happened to a remote node - if that node is a coordinator, we mark the parent repair session id as failed.
- coordinator - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- coordinator - Variable in class org.apache.cassandra.tracing.TraceState
-
- coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- coordinatorScanLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- copy(long) - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- copy() - Method in class org.apache.cassandra.config.CFMetaData
-
- copy(UUID) - Method in class org.apache.cassandra.config.CFMetaData
-
Clones the CFMetaData, but sets a different cfId
- copy(IPartitioner) - Method in class org.apache.cassandra.config.CFMetaData
-
- copy() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- copy() - Method in class org.apache.cassandra.config.ViewDefinition
-
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
-
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- copy(List<Relation>) - Method in class org.apache.cassandra.cql3.WhereClause
-
- copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.Clustering
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.ClusteringBound
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.ClusteringBoundary
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.DeletionInfo
-
- copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- copy() - Method in class org.apache.cassandra.db.Mutation
-
- copy() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy() - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command.
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- copy() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.BufferCell
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.Cell
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.CellPath
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- copy() - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Creates a copy of this Builder
.
- copy(Row, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Rows
-
- copy() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- copy(long) - Method in class org.apache.cassandra.io.util.Memory
-
- copy(long) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- 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(ByteBuffer, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, Object, long, long) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command with isDigestQuery set to true.
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- copyOpts(CFMetaData, CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
-
- copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- copyTo(DataInput, OutputStream, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- copyWithNewCompactValueType(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
-
- correspondingMessagingVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- CorruptBlockException - Exception in org.apache.cassandra.io.compress
-
- CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, CompressionMetadata.Chunk, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptFileException - Exception in org.apache.cassandra.io.util
-
- CorruptFileException(Exception, String) - Constructor for exception org.apache.cassandra.io.util.CorruptFileException
-
- CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
-
- CorruptSSTableException(Throwable, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- CorruptSSTableException(Throwable, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- count() - Method in class org.apache.cassandra.db.CBuilder
-
- count - Variable in class org.apache.cassandra.db.ClockAndCount
-
- count() - Method in class org.apache.cassandra.db.filter.DataLimits
-
The max number of results this limits enforces.
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The total number of bytes initially available in the byte array
buf
.
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- count() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
The total number of events that have occurred since this object was created.
- count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- countAllBatches() - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- countAllBatches() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
-
Counts all batches currently in the batchlog.
- 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(int, boolean, boolean) - Constructor for class org.apache.cassandra.db.filter.DataLimits.Counter
-
- counter(LegacyLayout.LegacyCellName, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- counter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- counter(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- counter_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- counter_cache_save_period - Variable in class org.apache.cassandra.config.Config
-
- counter_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- COUNTER_MASK - Static variable in class org.apache.cassandra.db.LegacyLayout
-
- COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.LegacyLayout
-
- counter_write_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- counterCache - Variable in class org.apache.cassandra.service.CacheService
-
- CounterCacheKey - Class in org.apache.cassandra.cache
-
- CounterCacheKey(Pair<String, String>, ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.cache.CounterCacheKey
-
- 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
-
- counterUpdate(CFMetaData, ByteBuffer, ByteBuffer, long) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- countLocalEndpoints(Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- countPaged(CFMetaData, DecoratedKey, ColumnFilter, ClusteringIndexFilter, DataLimits, ConsistencyLevel, ClientState, int, int, boolean, long) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
- countRowsFunction - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The function used to count the number of rows of a result set.
- coverInMap(ConcurrentMap<K, IntegerInterval>, K, int) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- covers(IntegerInterval) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Returns true if the set completely covers the given interval.
- covers(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Returns true if the set completely covers the given interval.
- CQL3CasRequest - Class in org.apache.cassandra.cql3.statements
-
Processed CAS conditions and update on potentially multiple rows of the same partition.
- CQL3CasRequest(CFMetaData, DecoratedKey, boolean, PartitionColumns, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- CQL3Type - Interface in org.apache.cassandra.cql3
-
- CQL3Type.Collection - Class in org.apache.cassandra.cql3
-
- CQL3Type.Custom - Class in org.apache.cassandra.cql3
-
- CQL3Type.Native - Enum in org.apache.cassandra.cql3
-
- CQL3Type.Raw - Class in org.apache.cassandra.cql3
-
- CQL3Type.Tuple - Class in org.apache.cassandra.cql3
-
- CQL3Type.UserDefined - Class in org.apache.cassandra.cql3
-
- Cql_Lexer - Class in org.apache.cassandra.cql3
-
- Cql_Lexer() - Constructor for class org.apache.cassandra.cql3.Cql_Lexer
-
- Cql_Lexer(CharStream, CqlLexer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer
-
- Cql_Lexer(CharStream, RecognizerSharedState, CqlLexer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer
-
- Cql_Lexer.DFA12 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA21 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA24 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA31 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA34 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA39 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA48 - Class in org.apache.cassandra.cql3
-
- Cql_Lexer.DFA55 - Class in org.apache.cassandra.cql3
-
- Cql_Parser - Class in org.apache.cassandra.cql3
-
- Cql_Parser(TokenStream, CqlParser) - Constructor for class org.apache.cassandra.cql3.Cql_Parser
-
- Cql_Parser(TokenStream, RecognizerSharedState, CqlParser) - Constructor for class org.apache.cassandra.cql3.Cql_Parser
-
- Cql_Parser.DFA1 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA15 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA154 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA155 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA173 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA175 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA177 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA179 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA182 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA190 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA195 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA196 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA205 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.DFA44 - Class in org.apache.cassandra.cql3
-
- Cql_Parser.mbean_return - Class in org.apache.cassandra.cql3
-
- Cql_Parser.username_return - Class in org.apache.cassandra.cql3
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- CqlBulkOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The CqlBulkOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
bound variable values) as CQL rows (and respective columns) in a given
table.
- CqlBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- CqlBulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop.cql3
-
- CqlBulkRecordWriter - Class in org.apache.cassandra.hadoop.cql3
-
The CqlBulkRecordWriter
maps the output <key, value>
pairs to a Cassandra column family.
- CqlBulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop.cql3
-
- CqlBulkRecordWriter.NullOutputHandler - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- CQLFragmentParser - Class in org.apache.cassandra.cql3
-
Helper class to encapsulate common code that calls one of the generated methods in CqlParser
.
- CQLFragmentParser() - Constructor for class org.apache.cassandra.cql3.CQLFragmentParser
-
- CQLFragmentParser.CQLParserFunction<R> - Interface in org.apache.cassandra.cql3
-
- CqlInputFormat - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- CqlInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- CqlLexer - Class in org.apache.cassandra.cql3
-
- CqlLexer() - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer.DFA1 - Class 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
-
- CQLMetrics - Class in org.apache.cassandra.metrics
-
- CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
-
- CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The CqlOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
bound variable values) as CQL rows (and respective columns) in a given
table.
- CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- CqlParser - Class in org.apache.cassandra.cql3
-
- CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlRecordReader - Class in org.apache.cassandra.hadoop.cql3
-
CqlRecordReader reads the rows return from the CQL query
It uses CQL auto-paging.
- CqlRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- CQLSSTableWriter - Class in org.apache.cassandra.io.sstable
-
Utility to write SSTables.
- CQLSSTableWriter.Builder - Class in org.apache.cassandra.io.sstable
-
A Builder for a CQLSSTableWriter object.
- cqlStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- cqlStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CQLStatement - Interface in org.apache.cassandra.cql3
-
- CQLTypeParser - Class in org.apache.cassandra.schema
-
- CQLTypeParser() - Constructor for class org.apache.cassandra.schema.CQLTypeParser
-
- CRC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.schema.CompressionParams
-
Deprecated.
- crcCheckChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- crcCheckChance - Variable in class org.apache.cassandra.schema.TableParams.Builder
-
- crcCheckChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- crcCheckChance - Variable in class org.apache.cassandra.schema.TableParams
-
- create() - Method in interface org.apache.cassandra.cache.CacheProvider
-
- create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- create(Pair<String, String>, ByteBuffer, Clustering, ColumnDefinition, CellPath) - Static method in class org.apache.cassandra.cache.CounterCacheKey
-
- create() - Method in class org.apache.cassandra.cache.NopCacheProvider
-
- create() - Method in class org.apache.cassandra.cache.OHCProvider
-
- create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create() - Method in class org.apache.cassandra.cache.SerializingCacheProvider
-
- create() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
This creates a new ExecutorLocals object based on what is already set.
- create(TraceState) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
- create(String, String) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- create(String, String, boolean, boolean, boolean) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- create(String, String, boolean, boolean, boolean, boolean) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- create(String, String, UUID, boolean, boolean, boolean, boolean, boolean, List<ColumnDefinition>, IPartitioner) - Static method in class org.apache.cassandra.config.CFMetaData
-
- 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(Functions, FunctionName, List<AbstractType<?>>, AbstractType<?>, FunctionName, FunctionName, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- create(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
- create(ConsistencyLevel, List<ByteBuffer>, boolean, int, PagingState, ConsistencyLevel, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- create(ResultSet) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(List<Map<String, ByteBuffer>>) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(SelectStatement, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(SelectStatement, ConsistencyLevel, ClientState, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
This method is intended for testing purposes, since it executes query on cluster
and not on the local node only.
- create(ClusteringComparator) - Static method in class org.apache.cassandra.db.CBuilder
-
- create(long, long) - Static method in class org.apache.cassandra.db.ClockAndCount
-
- create(ClusteringPrefix.Kind, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBound
-
- create(ClusteringComparator, boolean, boolean, Object...) - Static method in class org.apache.cassandra.db.ClusteringBound
-
- create(ClusteringPrefix.Kind, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBoundary
-
- create(ClusteringPrefix.Kind, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- create(ColumnFamilyStore, int, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(ColumnFamilyStore, int, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create() - Static method in class org.apache.cassandra.db.filter.RowFilter
-
- create(int) - Static method in class org.apache.cassandra.db.filter.RowFilter
-
- create(Clustering, ColumnDefinition) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- create(long, int) - Static method in class org.apache.cassandra.db.LivenessInfo
-
- create(long, int, int) - Static method in class org.apache.cassandra.db.LivenessInfo
-
- create(ClusteringComparator, boolean) - Static method in class org.apache.cassandra.db.MultiCBuilder
-
Creates a new empty MultiCBuilder
.
- create(boolean, CFMetaData, int, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- create(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
-
Creates an ArrayBackedCachedPartition
holding all the data of the provided iterator.
- create(UnfilteredRowIterator, int, int) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
-
Creates an ArrayBackedCachedPartition
holding all the data of the provided iterator.
- create(RowIterator) - Static method in class org.apache.cassandra.db.partitions.FilteredPartition
-
Create a FilteredPartition holding all the rows of the provided iterator.
- create(UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
Creates an ImmutableBTreePartition
holding all the data of the provided iterator.
- create(UnfilteredRowIterator, boolean) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
Creates an ImmutableBTreePartition
holding all the data of the provided iterator.
- create(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
Creates an ImmutableBTreePartition
holding all the data of the provided iterator.
- create(UnfilteredRowIterator, int, boolean) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
Creates an ImmutableBTreePartition
holding all the data of the provided iterator.
- create(long, long, DeletionTime, long, int, int, List<IndexInfo>, int[], ISerializer<IndexInfo>) - Static method in class org.apache.cassandra.db.RowIndexEntry
-
- create(Clustering, LivenessInfo, Row.Deletion, Object[]) - Static method in class org.apache.cassandra.db.rows.BTreeRow
-
- create(Clustering, LivenessInfo, Row.Deletion, Object[], int) - Static method in class org.apache.cassandra.db.rows.BTreeRow
-
- create(ByteBuffer) - Static method in class org.apache.cassandra.db.rows.CellPath
-
- create(boolean, CFMetaData, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, IndexMetadata) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(CFMetaData, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(boolean, CFMetaData, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(CFMetaData, int, DecoratedKey, ColumnFilter, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(CFMetaData, int, DecoratedKey, Slice) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition slice command for the provided single slice.
- create(CFMetaData, int, DecoratedKey, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition slice command for the provided slices.
- create(CFMetaData, int, ByteBuffer, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition slice command for the provided slices.
- create(CFMetaData, int, DecoratedKey, NavigableSet<Clustering>) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition name command for the provided rows.
- create(CFMetaData, int, DecoratedKey, Clustering) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition name command for the provided row.
- create(CFMetaData, DataInputPlus, SerializationHeader, SerializationHelper, DeletionTime, boolean) - Static method in class org.apache.cassandra.db.UnfilteredDeserializer
-
- create(Function, Throwable) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- create(Mutation, long) - Static method in class org.apache.cassandra.hints.Hint
-
- create(Mutation, long, int) - Static method in class org.apache.cassandra.hints.Hint
-
- create(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Create metadata about given compressed file including uncompressed data length, chunk size
and list of the chunk offsets of the compressed data.
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- create(Descriptor, Long, Long, CFMetaData, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(Descriptor, long, long, int, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(CFMetaData, Descriptor, long, long, int, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(String, long, long, int, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(String, long, long, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(Descriptor, long, long, CFMetaData, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- create(SSTableReader, RandomAccessReader, DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- create(SSTableReader, FileDataInput, RowIndexEntry<?>, DecoratedKey, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- create(CFMetaData, DataInputPlus, SerializationHeader, SerializationHelper, DeletionTime) - Static method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
-
- create(ColumnFamilyStore, Descriptor, long, long, int, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- create(CFMetaData, Descriptor, long, long, int, SerializationHeader, Collection<Index>) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- create(ColumnFamilyStore, String, long, long, int, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- create(ColumnFamilyStore, String, long, long, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int, long) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
-
- create(String, KeyspaceParams) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- create(String, KeyspaceParams, Tables) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- create(String, KeyspaceParams, Tables, Views, Types, Functions) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- create(boolean, Map<String, String>) - Static method in class org.apache.cassandra.schema.KeyspaceParams
-
- create(String, String) - Static method in class org.apache.cassandra.schema.TriggerMetadata
-
- create(CFMetaData, Row, ProtocolVersion) - Static method in class org.apache.cassandra.service.pager.PagingState.RowMark
-
- 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, int) - Method in class org.apache.cassandra.tools.NodeProbeFactory
-
- create(String, int, String, String) - Method in class org.apache.cassandra.tools.NodeProbeFactory
-
- create(Message.Type, int, ProtocolVersion, EnumSet<Frame.Header.Flag>, ByteBuf) - Static method in class org.apache.cassandra.transport.Frame
-
- create(C, C) - Static method in class org.apache.cassandra.utils.Interval
-
- create(C, C, D) - Static method in class org.apache.cassandra.utils.Interval
-
- create() - Static method in interface org.apache.cassandra.utils.MBeanWrapper
-
- create(String, MBeanWrapper.OnException) - Static method in interface org.apache.cassandra.utils.MBeanWrapper
-
- create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
-
- create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>, Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(V) - Static method in class org.apache.cassandra.utils.Wrapped
-
- createAggregateStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createAggregateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateAggregateStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE AGGREGATE
statement parsed from a CQL query.
- CreateAggregateStatement(FunctionName, List<CQL3Type.Raw>, String, CQL3Type.Raw, String, Term.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Creates all storage-related directories.
- createBroken(FunctionName, List<AbstractType<?>>, AbstractType<?>, ByteBuffer, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- createBrokenFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
It can happen that a function has been declared (is listed in the scheam) but cannot
be loaded (maybe only on some nodes).
- createBuffer() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
-
- createCachedThreadpoolWithMaxSize(String) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Creates a thread pool that creates new threads as needed, but
will reuse previously constructed threads when they are
available.
- createClustering(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- createColumnFamilyStore(Keyspace, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, CFMetaData, Directories, boolean, boolean, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
This is only directly used by offline tools
- createColumnFromRow(UntypedResultSet.Row, Types) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompactionStrategyInstance(ColumnFamilyStore, CompactionParams) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompressor(ParameterizedClass) - Static method in class org.apache.cassandra.schema.CompressionParams
-
- createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- createConnection(InetAddress) - Method in class org.apache.cassandra.streaming.DefaultConnectionFactory
-
Connect to peer and start exchanging message.
- createConnection(InetAddress) - Method in interface org.apache.cassandra.streaming.StreamConnectionFactory
-
- createConnection() - Method in class org.apache.cassandra.streaming.StreamSession
-
- createConnection(InetAddress) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
-
- createCorrespondingCloseMarker(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- createCorrespondingOpenMarker(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- createdAt - Variable in class org.apache.cassandra.db.Mutation
-
- createDataResponse(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
-
- createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createDense(String, String, boolean, boolean) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- createDigestResponse(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
-
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createEndpointSnitch(boolean, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- createEntry(long, LongSet) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
-
- createExecutor() - Method in class org.apache.cassandra.repair.RepairSession
-
- createFake(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
There is a couple of places in the code where we need a CFMetaData object and don't have one readily available
and know that only the keyspace and name matter.
- createFromMap(Map<?, ?>, EncryptionContext) - Static method in class org.apache.cassandra.security.EncryptionContext
-
If encryption headers are found in the parameters
,
those headers are merged with the application-wide encryptionContext
.
- createFunctionStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createFunctionStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateFunctionStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE FUNCTION
statement parsed from a CQL query.
- CreateFunctionStatement(FunctionName, String, String, List<ColumnIdentifier>, List<CQL3Type.Raw>, CQL3Type.Raw, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- createGlobal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single global, 2.1+ shard (a result of increment).
- createHardLink(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createHook() - Static method in interface org.apache.cassandra.db.StorageHook
-
- createHook() - Static method in interface org.apache.cassandra.streaming.StreamHook
-
- createIndexStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(CFName, IndexName, List<IndexTarget.Raw>, IndexPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- createInRelation(List<ColumnDefinition.Raw>, List<? extends Term.MultiColumnRaw>) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column IN relation with a list of IN values or markers.
- createInRelation(ColumnDefinition.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- createJMXServer(int, boolean) - Static method in class org.apache.cassandra.utils.JMXServerUtils
-
Creates a server programmatically.
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, KeyspaceAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- createLifecycleNewTracker() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- createLinks(String) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- createLinks(Descriptor, Set<Component>, String) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- createLocal(UUID, long, Collection<Mutation>) - Static method in class org.apache.cassandra.batchlog.Batch
-
Creates a 'local' batch - with all enclosed mutations in decoded form (as Mutation instances)
- createLocal(long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single local shard.
- createMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- createMessage() - Method in class org.apache.cassandra.db.Mutation
-
- createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.Mutation
-
- createMessage(int) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- createMessage(int) - Method in class org.apache.cassandra.db.ReadCommand
-
Creates a message for this command.
- createMessage(int) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- createMessage() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- createMessage() - Method in class org.apache.cassandra.db.TruncateResponse
-
- createMessage() - Method in class org.apache.cassandra.db.Truncation
-
- createMessage() - Static method in class org.apache.cassandra.db.WriteResponse
-
- createMessage() - Method in class org.apache.cassandra.repair.messages.RepairMessage
-
- createMessage(boolean, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
Create serialized message.
- createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- createMessageOut() - Method in class org.apache.cassandra.hints.HintMessage
-
- createMetricName(String) - Method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
-
Create a qualified name from given metric name.
- createNonInRelation(List<ColumnDefinition.Raw>, Operator, Term.MultiColumnRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column EQ, LT, LTE, GT, or GTE relation.
- createNotification(String) - Static method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- createRangeAware(CFMetaData, long, long, SSTableFormat.Type, int, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- createReader() - Method in class org.apache.cassandra.io.util.FileHandle
-
- createReader(RateLimiter) - Method in class org.apache.cassandra.io.util.FileHandle
-
- createReader(long) - Method in class org.apache.cassandra.io.util.FileHandle
-
- createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
-
- createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- createRemote(UUID, long, Collection<ByteBuffer>) - Static method in class org.apache.cassandra.batchlog.Batch
-
Creates a 'remote' batch - with all enclosed mutations in encoded form (as ByteBuffer instances)
The mutations will always be encoded using the current messaging version.
- createRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single remote shard.
- createRemoteDataResponse(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
-
- createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- createResponse(UnfilteredPartitionIterator) - 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() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateRoleStatement(RoleName, RoleOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- createSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
On segment creation, flag whether the segment should accept CDC mutations or not based on the total currently
allocated unflushed CDC segments and the contents of cdc_raw
- createSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
-
- createServerSocket(int) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
-
- createSingleMarkerInRelation(List<ColumnDefinition.Raw>, Tuples.INRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column IN relation with a marker for the IN values.
- createSocket(String, int) - Method in class org.apache.cassandra.utils.RMIClientSocketFactoryImpl
-
- createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
-
- createSslHandler() - Method in class org.apache.cassandra.transport.Server.AbstractSecureIntializer
-
- createSSTableAndLengthPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- createSSTableAndMinTimestampPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- createSSTableMultiWriter(Descriptor, long, long, int, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createSSTableMultiWriter(Descriptor, long, long, MetadataCollector, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createSSTableMultiWriter(Descriptor, long, long, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- createSSTableMultiWriter(Descriptor, long, long, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- createSuper(String, String, boolean) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- 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
-
- createTableHistogram(String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
-
Create a histogram-like interface that will register both a CF, keyspace and global level
histogram and forward any updates to both
- createTableHistogram(String, String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
-
- createTableParamsFromRow(UntypedResultSet.Row) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- createTableStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateTableStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE TABLE
parsed from a CQL query statement.
- CreateTableStatement(CFName, TableParams, boolean, Set<ColumnIdentifier>, UUID) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- CreateTableStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- createTableTimer(String, Timer) - Method in class org.apache.cassandra.metrics.TableMetrics
-
- createTableTimer(String, String, Timer) - Method in class org.apache.cassandra.metrics.TableMetrics
-
- createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createThread(Runnable) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- createThread(Runnable, String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- createThread(Runnable, String, boolean) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- createThread(ThreadGroup, Runnable, String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- createThread(ThreadGroup, Runnable, String, boolean) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- createTokenAllocator(NavigableMap<Token, InetAddress>, ReplicationStrategy<InetAddress>, 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(CFMetaData, DataInputPlus, SerializationHeader, SerializationHelper, DeletionTime) - Static method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
-
- createTracingSession(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.service.QueryState
-
- createTriggerStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTriggerStatement(CFName, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- createType() - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- createTypeStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateTypeStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTypeStatement(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- 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.
- createUserStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- createUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- createView(String, String) - Static method in class org.apache.cassandra.config.CFMetaData.Builder
-
- CreateViewStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateViewStatement(CFName, CFName, List<RawSelector>, WhereClause, List<ColumnDefinition.Raw>, List<ColumnDefinition.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateViewStatement
-
- createWithFixedPoolSize(String, int) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Returns a ThreadPoolExecutor with a fixed number of threads.
- createWithMaximumPoolSize(String, int, int, TimeUnit) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Returns a ThreadPoolExecutor with a fixed maximum number of threads, but whose
threads are terminated when idle for too long.
- createWriter(ColumnFamilyStore, File, long, long, SSTableReader, LifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- createWriter(ColumnFamilyStore, long, long, SSTableFormat.Type) - Method in class org.apache.cassandra.streaming.StreamReader
-
- createWriterForAntiCompaction(ColumnFamilyStore, File, int, long, Collection<SSTableReader>, ILifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- creationTime - Variable in class org.apache.cassandra.batchlog.Batch
-
- credentials - Variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- credentials_cache_max_entries - Variable in class org.apache.cassandra.config.Config
-
- credentials_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- credentials_validity_in_ms - Variable in class org.apache.cassandra.config.Config
-
- CredentialsMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- CredentialsMessage() - Constructor for class org.apache.cassandra.transport.messages.CredentialsMessage
-
- cross_node_timeout - Variable in class org.apache.cassandra.config.Config
-
- crossNodeDroppedLatency - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
The cross node dropped latency
- crossNodeLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics
-
- CSLM_OVERHEAD - Static variable in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
-
- csZoneDc - Variable in class org.apache.cassandra.locator.CloudstackSnitch
-
- csZoneRack - Variable in class org.apache.cassandra.locator.CloudstackSnitch
-
- CTOR_SIG - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
-
- current(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
-
- current() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
returns the currently visible readers managed by this transaction
- current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
return the current version of the provided reader, whether or not it is visible or staged;
i.e.
- current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- CURRENT - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
-
- current() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
- current() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- current() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- CURRENT - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
-
The preferred versions
- current() - Method in class org.apache.cassandra.utils.btree.BTreeSearchIterator
-
- current() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
-
- 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.index.sasi.disk.Descriptor
-
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- currentBlocked - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- currentBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- currentBlockIdx() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- currentBuffer() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- currentClustering() - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- currentIndex() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- currentlyRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- currentRowClustering() - Method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
The clustering of the current row of the cell grouper, or null
if no row is currently started.
- currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- currentTimeMillis() - Static method in class org.apache.cassandra.db.monitoring.ApproximateTime
-
- currentTimeMillis() - Method in class org.apache.cassandra.utils.Clock
-
- currentTimeMillis() - Method in class org.apache.cassandra.utils.SystemTimeSource
-
- currentTimeMillis() - Method in interface org.apache.cassandra.utils.TimeSource
-
- currentTimeout() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- currentWriter() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- Cursor<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
-
A
Cursor
can be used to traverse a
Trie
, visit each node
step by step and make
Cursor.Decision
s on each step how to continue with
traversing the
Trie
.
- Cursor.Decision - Enum in org.apache.cassandra.index.sasi.utils.trie
-
- Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- custom(double) - Static method in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- CUSTOM_EXPRESSION_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- CUSTOM_EXPRESSIONS_NOT_ALLOWED - Static variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- customClass - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- CustomClassLoader - Class in org.apache.cassandra.triggers
-
Custom class loader will load the classes from the class path, CCL will load
the classes from the the URL first, if it cannot find the required class it
will let the parent class loader do the its job.
- CustomClassLoader(ClassLoader) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
-
- CustomClassLoader(ClassLoader, File) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
-
- CustomExpression(CFMetaData, IndexMetadata, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.CustomExpression
-
- customExpressionValueType() - Method in interface org.apache.cassandra.index.Index
-
If the index supports custom search expressions using the
SELECT * FROM table WHERE expr(index_name, expression) syntax, this
method should return the expected type of the expression argument.
- customExpressionValueType() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- customExpressionValueType() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- CustomFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- customIndexExpression(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- customIndexExpression(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.CqlParser
-
- CustomIndexExpression - Class in org.apache.cassandra.cql3.restrictions
-
- CustomIndexExpression(IndexName, Term.Raw) - Constructor for class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
-
- CustomPayloadMirroringQueryHandler - Class in org.apache.cassandra.cql3
-
Custom QueryHandler that sends custom request payloads back with the result.
- CustomPayloadMirroringQueryHandler() - Constructor for class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- CustomTNonBlockingServer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer(TNonblockingServer.Args) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- CustomTNonBlockingServer.CustomFrameBuffer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
-
- CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
-
Slightly modified version of the Apache Thrift TThreadPoolServer.
- CustomTThreadPoolServer(TThreadPoolServer.Args, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- CustomTThreadPoolServer.Factory - Class in org.apache.cassandra.thrift
-
- D - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- D - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- D - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- D - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- daemonInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- daemonInitialization(Supplier<Config>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- DATA - Static variable in class org.apache.cassandra.io.sstable.Component
-
- data - Variable in class org.apache.cassandra.utils.Interval
-
- data_file_directories - Variable in class org.apache.cassandra.config.Config
-
- DatabaseDescriptor - Class in org.apache.cassandra.config
-
- DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
-
- DataBlock(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataBlock
-
- datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- DATACENTERS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- DatacenterSyncWriteResponseHandler<T> - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
- DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Keyspace, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- DatacenterWriteResponseHandler<T> - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
- DatacenterWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Keyspace, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- dataDirectories - Static variable in class org.apache.cassandra.db.Directories
-
- DataDirectory(File) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
-
- dataFile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- DataInputBuffer - Class in org.apache.cassandra.io.util
-
Input stream around a single ByteBuffer.
- DataInputBuffer(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
-
- DataInputBuffer(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
-
- DataInputBuffer(byte[]) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
-
- DataInputPlus - Interface in org.apache.cassandra.io.util
-
Extension to DataInput that provides support for reading varints
- DataInputPlus.DataInputStreamPlus - Class in org.apache.cassandra.io.util
-
Wrapper around an InputStream that provides no buffering but can decode varints
- DataInputStreamPlus(InputStream) - Constructor for class org.apache.cassandra.io.util.DataInputPlus.DataInputStreamPlus
-
- DataIntegrityMetadata - Class in org.apache.cassandra.io.util
-
- DataIntegrityMetadata() - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- DataIntegrityMetadata.ChecksumValidator - Class in org.apache.cassandra.io.util
-
- DataIntegrityMetadata.FileDigestValidator - Class in org.apache.cassandra.io.util
-
- dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- dataLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- dataLength() - Method in class org.apache.cassandra.io.util.FileHandle
-
- dataLevel - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- DataLevel(long, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
-
- DataLimits - Class in org.apache.cassandra.db.filter
-
Object in charge of tracking if we have fetch enough data for a given query.
- DataLimits() - Constructor for class org.apache.cassandra.db.filter.DataLimits
-
- DataLimits.Counter - Class in org.apache.cassandra.db.filter
-
- DataLimits.Kind - Enum in org.apache.cassandra.db.filter
-
- DataLimits.Serializer - Class in org.apache.cassandra.db.filter
-
- DataOutputBuffer - Class in org.apache.cassandra.io.util
-
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing
its buffer so copies can be avoided.
- DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputBuffer(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputBufferFixed - Class in org.apache.cassandra.io.util
-
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing
its buffer so copies can be avoided.
- DataOutputBufferFixed() - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- DataOutputBufferFixed(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- DataOutputBufferFixed(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- DataOutputPlus - Interface in org.apache.cassandra.io.util
-
Extension to DataOutput that provides for writing ByteBuffer and Memory, potentially with an efficient
implementation that is zero copy or at least has reduced bounds checking overhead.
- DataOutputStreamPlus - Class in org.apache.cassandra.io.util
-
Abstract base class for DataOutputStreams that accept writes from ByteBuffer or Memory and also provide
access to the underlying WritableByteChannel associated with their output stream.
- DataOutputStreamPlus() - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- DataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- DataPosition - Interface in org.apache.cassandra.io.util
-
- dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadFailureException
-
- dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- DataRange - Class in org.apache.cassandra.db
-
Groups both the range of partitions to query, and the clustering index filter to
apply for each partition (for a (partition) range query).
- DataRange(AbstractBounds<PartitionPosition>, ClusteringIndexFilter) - Constructor for class org.apache.cassandra.db.DataRange
-
Creates a DataRange
given a range of partition keys and a clustering index filter.
- dataRange() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- dataRange() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- DataRange.Paging - Class in org.apache.cassandra.db
-
Specialized DataRange
used for the paging case.
- DataRange.Serializer - Class in org.apache.cassandra.db
-
- DataResolver - Class in org.apache.cassandra.service
-
- DataResource - Class in org.apache.cassandra.auth
-
The primary type of resource in Cassandra.
- dataResource() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dataResource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- dataSize() - Method in class org.apache.cassandra.db.AbstractClusteringPrefix
-
- 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.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
-
- 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 - Enum in org.apache.cassandra.transport
-
- DataType.Codec - Class in org.apache.cassandra.transport
-
- dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
- dateStringToDays(String) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- dateStringToTimestamp(String) - Static method in class org.apache.cassandra.serializers.TimestampSerializer
-
- DateTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- DateTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- DateTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- DateTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- DateTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- dateToTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type TIMESTAMP
into a DATE
.
- dateToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type DATE
into an UNIX timestamp.
- DateType - Class in org.apache.cassandra.db.marshal
-
Deprecated.
- DAYS_PER_WEEK - Static variable in class org.apache.cassandra.cql3.Duration
-
- dayToTimeInMillis(int) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- dcLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics
-
- dcLocalReadRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- dcLocalReadRepairChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- dcLocalReadRepairChance - Variable in class org.apache.cassandra.schema.TableParams
-
- deactivate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to stop and destroy the daemon in one shot.
- debug(String) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
-
- debug - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- DEBUG - Static variable in class org.apache.cassandra.utils.memory.BufferPool
-
- debug(String) - Method in interface org.apache.cassandra.utils.OutputHandler
-
- debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
-
- debug - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- DEBUG_ENABLED - Static variable in class org.apache.cassandra.utils.concurrent.Ref
-
- DebuggableScheduledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
-
Like DebuggableThreadPoolExecutor, DebuggableScheduledThreadPoolExecutor always
logs exceptions from the tasks it is given, even if Future.get is never called elsewhere.
- DebuggableScheduledThreadPoolExecutor(int, String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- DebuggableScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- DebuggableScheduledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- DebuggableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
-
This class encorporates some Executor best practices for Cassandra.
- DebuggableThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- DebuggableThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- DebuggableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- debugGap(long) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- debugString() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- debugTimestamp(long) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- debugTimestamps(Collection<C>) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- DecayingEstimatedHistogramReservoir - Class in org.apache.cassandra.metrics
-
A decaying histogram reservoir where values collected during each minute will be twice as significant as the values
collected in the previous minute.
- DecayingEstimatedHistogramReservoir() - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Construct a decaying histogram with default number of buckets and without considering zeroes.
- DecayingEstimatedHistogramReservoir(boolean) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Construct a decaying histogram with default number of buckets.
- DecayingEstimatedHistogramReservoir(boolean, int) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Construct a decaying histogram.
- DecimalSerializer - Class in org.apache.cassandra.serializers
-
- DecimalSerializer() - Constructor for class org.apache.cassandra.serializers.DecimalSerializer
-
- DecimalType - Class in org.apache.cassandra.db.marshal
-
- decode(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
-
- decode(ByteBuf, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Decoder
-
- decode(ChannelHandlerContext, Frame, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Decompressor
-
- decode(ChannelHandlerContext, Frame, List) - Method in class org.apache.cassandra.transport.Message.ProtocolDecoder
-
- decode(int, ProtocolVersionLimit) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
-
- decodeCellName(CFMetaData, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeCellName(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeCellName(CFMetaData, ByteBuffer, boolean) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeClustering(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
Used at search time to convert a row in the index table into a simple struct containing the values required
to retrieve the corresponding row from the base table.
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndexBase
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
-
- decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
-
- decodeJson(String) - Static method in class org.apache.cassandra.cql3.Json
-
- decodeOne(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.DataType.Codec
-
- Decoder(Connection.Factory, ProtocolVersionLimit) - Constructor for class org.apache.cassandra.transport.Frame.Decoder
-
- decodeSliceBound(CFMetaData, ByteBuffer, boolean) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeTombstoneBound(CFMetaData, ByteBuffer, boolean) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- decodeZigZag64(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Decode a ZigZag-encoded 64-bit value.
- decommission() - Method in class org.apache.cassandra.service.StorageService
-
- decommission() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
transfer this node's data to other machines and remove it from service.
- decommission() - Method in class org.apache.cassandra.tools.NodeProbe
-
- Decommission - Class in org.apache.cassandra.tools.nodetool
-
- Decommission() - Constructor for class org.apache.cassandra.tools.nodetool.Decommission
-
- decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
-
- decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
Used by UDF implementations (both Java code generated by
JavaBasedUDFunction
and script executor
ScriptBasedUDFunction
) to convert the Java
object representation for the return value to the C* serialized representation.
- decompose(TypeCodec<Object>, ProtocolVersion, Object) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- decompose(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- decompose(Long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
decomposes a uuid into raw bytes.
- decompress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- Decompressor() - Constructor for class org.apache.cassandra.transport.Frame.Decompressor
-
- 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.config.CFMetaData
-
- 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
-
- decrement() - Method in class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
-
- decrement() - Method in class org.apache.cassandra.utils.WrappedInt
-
- decrypt(ReadableByteChannel, ByteBuffer, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
-
Decrypt the input data, as well as manage sizing of the outputBuffer
; if the buffer is not big enough,
deallocate current, and allocate a large enough buffer.
- decrypt(FileDataInput, ByteBuffer, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
-
- DEFAULT - Static variable in class org.apache.cassandra.cql3.BatchQueryOptions
-
- DEFAULT - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- DEFAULT - Static variable in class org.apache.cassandra.io.util.SequentialWriterOption
-
Default write option.
- DEFAULT - Static variable in class org.apache.cassandra.schema.CachingParams
-
- DEFAULT - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT - Static variable in class org.apache.cassandra.schema.CompressionParams
-
- DEFAULT - Static variable in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- DEFAULT - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_BASE_TIME_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- DEFAULT_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
The default number of decayingBuckets.
- DEFAULT_BUCKET_HIGH - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_BUCKET_LOW - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- DEFAULT_CHUNK_LENGTH - Static variable in class org.apache.cassandra.schema.CompressionParams
-
- DEFAULT_COMMENT - Static variable in class org.apache.cassandra.schema.TableParams
-
- 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_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- DEFAULT_CQL_VERSION - Static variable in class org.apache.cassandra.service.ClientState
-
- DEFAULT_CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_DCLOCAL_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_DEFAULT_TIME_TO_LIVE - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_DURABLE_WRITES - Static variable in class org.apache.cassandra.schema.KeyspaceParams
-
- DEFAULT_ENABLED - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT_EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- DEFAULT_EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- DEFAULT_FAIL_THRESHOLD - Static variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
-
- DEFAULT_GC_GRACE_SECONDS - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_HOST - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- DEFAULT_JMX_PORT - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- DEFAULT_LEVEL_FANOUT_SIZE - Static variable in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- DEFAULT_LOCAL_DURABLE_WRITES - Static variable in class org.apache.cassandra.schema.KeyspaceParams
-
- DEFAULT_LOG_ALL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- DEFAULT_MAX_FRAME_SIZE - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- DEFAULT_MAX_INDEX_INTERVAL - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_MAX_SSTABLE_AGE_DAYS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
Deprecated.
- DEFAULT_MAX_THRESHOLD - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- DEFAULT_MAX_WINDOW_SIZE_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- DEFAULT_MEMTABLE_FLUSH_PERIOD_IN_MS - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_MIN_INDEX_INTERVAL - Static variable in class org.apache.cassandra.schema.TableParams
-
- DEFAULT_MIN_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_MIN_THRESHOLD - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT_MIN_TOKEN_LENGTH - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- DEFAULT_PAGE_SIZE - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- DEFAULT_PAGE_SIZE - Static variable in class org.apache.cassandra.index.SecondaryIndexManager
-
- DEFAULT_PROVIDE_OVERLAPPING_TOMBSTONES - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.schema.TableParams
-
- 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_THRESHOLDS - Static variable in class org.apache.cassandra.schema.CompactionParams
-
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- DEFAULT_TIMESTAMP_RESOLUTION - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- DEFAULT_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_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- DEFAULT_WITH_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- DEFAULT_WITHOUT_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- DEFAULT_ZERO_CONSIDERATION - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- defaultClusteringName() - Method in class org.apache.cassandra.db.CompactTables.DefaultNames
-
- DefaultCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
-
The default compaction writer - creates one output file in L0
- DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
-
- DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, boolean, int) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
-
Deprecated.
- DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, int) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
-
- defaultCompactValueName() - Method in class org.apache.cassandra.db.CompactTables.DefaultNames
-
- DefaultConnectionFactory - Class in org.apache.cassandra.streaming
-
- DefaultConnectionFactory() - Constructor for class org.apache.cassandra.streaming.DefaultConnectionFactory
-
- DefaultFSErrorHandler - Class in org.apache.cassandra.service
-
- DefaultFSErrorHandler() - Constructor for class org.apache.cassandra.service.DefaultFSErrorHandler
-
- DefaultNameFactory - Class in org.apache.cassandra.metrics
-
MetricNameFactory that generates default MetricName of metrics.
- DefaultNameFactory(String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
-
- DefaultNameFactory(String, String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
-
- defaultNameGenerator(Set<String>) - Static method in class org.apache.cassandra.db.CompactTables
-
- defaultNameGenerator(Iterable<ColumnDefinition>) - Static method in class org.apache.cassandra.db.CompactTables
-
- defaultPartitionKeyName() - Method in class org.apache.cassandra.db.CompactTables.DefaultNames
-
- DefaultPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter.DefaultPrinter
-
- DefaultPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter.DefaultPrinter
-
- defaultStatsMetadata() - Static method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- DefaultStemmingFilter(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmingFilters.DefaultStemmingFilter
-
- DefaultStopWordFilter(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFilters.DefaultStopWordFilter
-
- defaultTimeToLive(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- defaultTimeToLive(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- defaultTimeToLive - Variable in class org.apache.cassandra.schema.TableParams
-
- DefaultValue<T> - Class in org.apache.cassandra.utils
-
- DefaultValue(T) - Constructor for class org.apache.cassandra.utils.DefaultValue
-
- defined - Variable in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- DefinitionsUpdateVerbHandler - Class in org.apache.cassandra.db
-
Called when node receives updated schema state from the schema migration coordinator node.
- DefinitionsUpdateVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
-
- deflate() - Static method in class org.apache.cassandra.schema.CompressionParams
-
- deflate(Integer) - Static method in class org.apache.cassandra.schema.CompressionParams
-
- DeflateCompressor - Class in org.apache.cassandra.io.compress
-
- DelayedValue(List<Term>) - Constructor for class org.apache.cassandra.cql3.Lists.DelayedValue
-
- DelayedValue(Comparator<ByteBuffer>, Map<Term, Term>) - Constructor for class org.apache.cassandra.cql3.Maps.DelayedValue
-
- DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
-
- DelayedValue(TupleType, List<Term>) - Constructor for class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- DelayedValue(UserType, List<Term>) - Constructor for class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- delegate(int) - Method in class org.apache.cassandra.io.ForwardingVersionedSerializer
-
Returns the backing delegate instance that methods are forwarded to.
- 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(String) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Removes the value for a given column (creating a tombstone).
- delete() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
-
- delete() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
-
- delete(String) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
-
- delete(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
We use a ReferenceQueue to manage deleting files that have been compacted
and for which no more SSTable references exist.
- delete(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- delete(File...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteAllHints() - Method in class org.apache.cassandra.hints.HintsService
-
Deletes all hints for all destinations.
- deleteAllHints() - Method in interface org.apache.cassandra.hints.HintsServiceMBean
-
Irrevocably deletes all the stored hints files (with the exception of those that are being dispatched right now,
or being written to).
- deleteAllHintsForEndpoint(String) - Method in class org.apache.cassandra.hints.HintsService
-
Deletes all hints for the provided destination.
- deleteAllHintsForEndpoint(InetAddress) - Method in class org.apache.cassandra.hints.HintsService
-
Deletes all hints for the provided destination.
- deleteAllHintsForEndpoint(String) - Method in interface org.apache.cassandra.hints.HintsServiceMBean
-
Irrevocably deletes all the stored hints files for the target address (with the exception of those that are
being dispatched right now, or being written to).
- deleteAsync(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deletedSlice() - Method in class org.apache.cassandra.db.RangeTombstone
-
The slice of rows that is deleted by this range tombstone.
- deleteHintsForEndpoint(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
Deprecated.
- deleteHintsForEndpoint(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
Deprecated.
Nuke all hints from this node to `ep`.
- deleteOldSnapshots() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
-
- deleteOp() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- deleteOp() - Method in class org.apache.cassandra.cql3.CqlParser
-
- deletePartition(UnfilteredRowIterator, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Delete all data from all indexes for this partition.
- Deleter(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
-
- DeleterByField(ColumnDefinition, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.UserTypes.DeleterByField
-
- deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deletes all files and subdirectories under "dir".
- deleteRecursiveOnExit(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Schedules deletion of all file and subdirectories under "dir" on JVM shutdown.
- deletes(LivenessInfo) - Method in class org.apache.cassandra.db.DeletionTime
-
- deletes(Cell) - Method in class org.apache.cassandra.db.DeletionTime
-
- deletes(long) - Method in class org.apache.cassandra.db.DeletionTime
-
- deletes(LivenessInfo) - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- deletes(Cell) - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- deleteSelection() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- deleteSelection() - Method in class org.apache.cassandra.cql3.CqlParser
-
- deleteStaleEntry(DecoratedKey, Clustering, DeletionTime, OpOrder.Group) - 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() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- deleteStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DeleteStatement - Class in org.apache.cassandra.cql3.statements
-
A DELETE
parsed from a CQL query statement.
- DeleteStatement.Parsed - Class in org.apache.cassandra.cql3.statements
-
- deleteWithConfirm(String, boolean, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteWithConfirm(File, boolean, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleting - Variable in class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- deletion - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- deletion() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- deletion() - Method in interface org.apache.cassandra.db.rows.Row
-
The row deletion.
- Deletion(DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Deletion
-
- DELETION_MASK - Static variable in class org.apache.cassandra.db.LegacyLayout
-
- DeletionInfo - Interface in org.apache.cassandra.db
-
A combination of a top-level (partition) tombstone and range tombstones describing the deletions
within a partition.
- deletionInfo - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- deletionInfo() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- deletionInfo() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
- deletionInfo() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- DeletionPurger - Interface in org.apache.cassandra.db
-
- deletionTime() - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- DeletionTime - Class in org.apache.cassandra.db
-
Information on deletion of a storage engine object.
- DeletionTime(long, int) - Constructor for class org.apache.cassandra.db.DeletionTime
-
- deletionTime - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- deletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
-
The deletion time for this (range) tombstone.
- deletionTime() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- deletionTime() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
The deletion time for the range tombstone this is a bound of.
- DeletionTime.Serializer - Class in org.apache.cassandra.db
-
- deletionTimeSerializedSize(DeletionTime) - Method in class org.apache.cassandra.db.SerializationHeader
-
- DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- DELIMITER - Static variable in class org.apache.cassandra.index.sasi.analyzer.DelimiterTokenizingOptions
-
- DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- DelimiterAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
-
- DelimiterAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
-
- DelimiterTokenizingOptions - Class in org.apache.cassandra.index.sasi.analyzer
-
Simple tokenizer based on a specified delimiter (rather than whitespace).
- deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
-
- deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- dependsOn(ColumnDefinition) - Method in interface org.apache.cassandra.index.Index
-
Called to determine whether this index targets a specific column.
- dependsOn(ColumnDefinition) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- dependsOn(ColumnDefinition) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- DEPRECATED_MBEAN_NAME - Static variable in class org.apache.cassandra.db.DisallowedDirectories
-
- depth(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- desc - Variable in class org.apache.cassandra.cache.KeyCacheKey
-
- desc - Variable in exception org.apache.cassandra.exceptions.RepairException
-
- desc - Variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- desc - Variable in class org.apache.cassandra.repair.RepairResult
-
- desc - Variable in class org.apache.cassandra.repair.SyncTask
-
- desc - Variable in class org.apache.cassandra.repair.Validator
-
- desc(boolean) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
-
- descendingIterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_local_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_partitioner() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_schema_versions() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_snitch() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
-
Deprecated.
- describe_splits_ex(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_token_map() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_version() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- DescribeCluster - Class in org.apache.cassandra.tools.nodetool
-
- DescribeCluster() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeCluster
-
- describeLocalRing(String) - Method in class org.apache.cassandra.service.StorageService
-
The same as describeRing(String)
but considers only the part of the ring formed by nodes in the local DC.
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate the deltas between tokens in the ring in order to compare
relative sizes.
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- describeRing(String) - Method in class org.apache.cassandra.service.StorageService
-
The TokenRange for a given keyspace.
- describeRing(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- DescribeRing - Class in org.apache.cassandra.tools.nodetool
-
- DescribeRing() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeRing
-
- describeRingJMX(String) - Method in class org.apache.cassandra.service.StorageService
-
The same as describeRing(String)
but converts TokenRange to the String for JMX compatibility
- describeRingJMX(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
The same as describeRing(String)
but converts TokenRange to the String for JMX compatibility
- describeSchemaVersions() - Static method in class org.apache.cassandra.service.StorageProxy
-
initiate a request/response session with each live node to check whether or not everybody is using the same
migration id.
- description - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- description - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- description - Variable in class org.apache.cassandra.streaming.StreamResultFuture
-
- description() - Method in class org.apache.cassandra.streaming.StreamSession
-
- description - Variable in class org.apache.cassandra.streaming.StreamState
-
- descriptor - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- Descriptor - Class in org.apache.cassandra.index.sasi.disk
-
Object descriptor for SASIIndex files.
- Descriptor(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor
-
- descriptor - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- Descriptor - Class in org.apache.cassandra.io.sstable
-
A SSTable is described by the keyspace and column family it contains data
for, a generation (where higher generations contain more recent data) and
an alphabetic version string.
- Descriptor(File, String, String, int) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
A descriptor that assumes CURRENT_VERSION.
- Descriptor(File, String, String, int, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
Constructor for sstable writers only.
- Descriptor(String, File, String, String, int, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
- Descriptor(Version, File, String, String, int, SSTableFormat.Type, Component) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
- descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- Descriptor.Version - Class in org.apache.cassandra.index.sasi.disk
-
- deserialize(DataInputPlus, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.config.CFMetaData.Serializer
-
- deserialize(TypeCodec<?>, ProtocolVersion, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- deserialize(int) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
-
- deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
-
- deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- deserialize(ByteBuffer, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
-
- deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
-
- deserialize(DataInputPlus, CFMetaData) - Method in class org.apache.cassandra.db.Columns.Serializer
-
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.DataRange.Serializer
-
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData, boolean) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.InternalDeserializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
-
- deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
-
- deserialize(CFMetaData, DataInputPlus) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- deserialize(DataInputPlus, int, SerializationHelper.Flag) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
-
- deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
-
- deserialize(DataInputPlus, int, SerializationHelper.Flag, ByteBuffer) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
-
- deserialize(DataInputPlus, int, SerializationHelper.Flag, DecoratedKey) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
-
- deserialize(DataInputPlus, int, CFMetaData, ColumnFilter, SerializationHelper.Flag) - Method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
-
- deserialize(DataInputPlus, int, boolean, int, boolean, CFMetaData, int, ColumnFilter, RowFilter, DataLimits, IndexMetadata) - Method in class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
-
- deserialize(DataInputPlus, long) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- deserialize(DataInputPlus, long) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- deserialize(DataInputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
-
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData, SerializationHelper.Flag, UnfilteredRowIteratorSerializer.Header) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- deserialize(DataInputPlus, int, CFMetaData, ColumnFilter, SerializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- deserialize(DataInputPlus, SerializationHeader, SerializationHelper, Row.Builder) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
Deserialize an
Unfiltered
from the provided input.
- deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.db.Slices.Serializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.WriteResponse.Serializer
-
- deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- deserialize(DataInput, IPartitioner, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Deserialize into the specified DataInputStream instance.
- deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.io.ForwardingVersionedSerializer
-
- deserialize(DataInputPlus) - Method in interface org.apache.cassandra.io.ISerializer
-
Deserialize from the specified DataInput instance.
- deserialize(DataInputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Deserialize into the specified DataInputStream instance.
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
-
- deserialize(DataInputStream, IPartitioner, boolean, int, int) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- deserialize(Version, DataInputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Deserialize metadata component from given input.
- deserialize(Descriptor, EnumSet<MetadataType>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Deserialize specified metadata components from given descriptor.
- deserialize(Descriptor, MetadataType) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Deserialized only metadata component specified from given descriptor.
- deserialize(Descriptor, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
-
Deprecated.
Legacy serializer deserialize all components no matter what types are specified.
- deserialize(Descriptor, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- deserialize(Descriptor, MetadataType) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- deserialize(Descriptor, FileDataInput, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- deserialize(Version, 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(DataInput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.net.PingMessage.PingMessageSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- deserialize(DataInputPlus, int, CFMetaData) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DurationSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- deserialize(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
-
- deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- deserialize(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.service.pager.PagingState
-
It's possible to receive a V3 paging state on a V4 client session, and vice versa - so we cannot
blindly rely on the protocol version provided.
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- deserialize(ReadableByteChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- deserialize(ReadableByteChannel, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- deserialize(byte) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
- deserialize(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event
-
- deserialize(int) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- deserialize(DataInput, boolean, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
Deserialize an IntervalTree whose keys use the natural ordering.
- deserialize(DataInputPlus, int, Comparator<C>) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- deserializeCells(CFMetaData, DataInput, SerializationHelper.Flag, int) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- deserializeEvent(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
-
- deserializeFirstLastKey(DataInputStream, IPartitioner, boolean) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
Deserializes the first and last key stored in the summary
Only for use by offline tools like SSTableMetadataViewer, otherwise SSTable.first/last should be used.
- deserializeForCache(DataInputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- deserializeForCache(DataInputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- deserializeForMessaging(DataInputPlus, CFMetaData, ColumnFilter, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- deserializeForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- deserializeForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- deserializeForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- deserializeForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- deserializeFromSSTable(DataInput, Version) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Deserialize into the specified DataInputStream instance in the format
suited for SSTables.
- deserializeHeader(CFMetaData, ColumnFilter, DataInputPlus, int, SerializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- deserializeLegacyPartition(DataInputPlus, int, SerializationHelper.Flag, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- deserializeMarkerBody(DataInputPlus, SerializationHeader, ClusteringBoundOrBoundary) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- deserializeNextBound() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
-
- deserializeNextClustering() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
-
- deserializePositionAndSkip(DataInputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- deserializePositionAndSkip(DataInputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- Deserializer(ClusteringComparator, DataInputPlus, SerializationHeader) - Constructor for class org.apache.cassandra.db.ClusteringPrefix.Deserializer
-
- deserializer - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- deserializer - Variable in enum org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
-
- Deserializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
-
- deserializeRowBody(DataInputPlus, SerializationHeader, SerializationHelper, int, int, Row.Builder) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- deserializeStaticRow(DataInputPlus, SerializationHeader, SerializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- deserializeSubset(Columns, DataInputPlus) - Method in class org.apache.cassandra.db.Columns.Serializer
-
- deserializeTombstonesOnly(FileDataInput, SerializationHeader, SerializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- deserializeValues(DataInputPlus, ClusteringPrefix.Kind, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
-
- destroy() - Method in class org.apache.cassandra.service.CassandraDaemon
-
Clean up all resources obtained during the lifetime of the daemon.
- destroy() - Method in class org.apache.cassandra.service.NativeTransportService
-
Ultimately stops servers and closes all resources.
- destroyClientTransports() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- destroyConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- detail - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- dfa1 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA1(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA1
-
- dfa1 - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- DFA1(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlLexer.DFA1
-
- dfa12 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA12(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA12
-
- dfa15 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA15(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA15
-
- dfa154 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA154(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA154
-
- dfa155 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA155(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA155
-
- dfa173 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA173(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA173
-
- dfa175 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA175(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA175
-
- dfa177 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA177(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA177
-
- dfa179 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA179(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA179
-
- dfa182 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA182(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA182
-
- dfa190 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA190(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA190
-
- dfa195 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA195(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA195
-
- dfa196 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA196(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA196
-
- dfa205 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA205(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA205
-
- dfa21 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA21(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA21
-
- dfa24 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA24(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA24
-
- dfa31 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA31(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA31
-
- dfa34 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA34(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA34
-
- dfa39 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA39(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA39
-
- dfa44 - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DFA44(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Parser.DFA44
-
- dfa48 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA48(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA48
-
- dfa55 - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DFA55(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.Cql_Lexer.DFA55
-
- dfile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- DiagnosticSnapshotService - Class in org.apache.cassandra.utils
-
Provides a means to take snapshots when triggered by anomalous events or when the breaking of invariants is
detected.
- diff(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Determine the count relationship between two contexts.
- diff(RowDiffListener, Row, Row...) - Static method in class org.apache.cassandra.db.rows.Rows
-
Given the result (merged
) of merging multiple inputs
, signals the difference between
each input and merged
to diffListener
.
- 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.
- differenceToFetch(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Calculate set of the difference ranges of given two ranges
(as current (A, B] and rhs is (C, D])
which node will need to fetch when moving to a given new token
- DifferencingCounter(InetAddress) - Constructor for class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.AbstractClusteringPrefix
-
- digest(MessageDigest) - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Adds the data of this clustering prefix to the provided digest.
- digest(MessageDigest) - Method in class org.apache.cassandra.db.Columns
-
- digest(MessageDigest, Set<ByteBuffer>) - Method in class org.apache.cassandra.db.Columns
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.DeletionTime
-
- digest(CFMetaData, MessageDigest) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyUnfilteredPartition
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.LivenessInfo
-
Adds this liveness information to the provided digest.
- digest(ReadCommand, UnfilteredPartitionIterator, MessageDigest, 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(MessageDigest) - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- digest(MessageDigest, Set<ByteBuffer>) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.CellPath
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.ColumnData
-
Adds the data to the provided digest.
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- digest(MessageDigest, Set<ByteBuffer>) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- digest(MessageDigest, Set<ByteBuffer>) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- digest(MessageDigest) - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- digest(RowIterator, MessageDigest, MessageDigest, Set<ByteBuffer>) - Static method in class org.apache.cassandra.db.rows.RowIterators
-
- digest(MessageDigest) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
Digest the atom using the provided MessageDigest
.
- digest(MessageDigest, Set<ByteBuffer>) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
Digest the atom using the provided MessageDigest
.
- digest(ReadCommand, UnfilteredRowIterator, MessageDigest, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Digests the partition represented by the provided iterator.
- DIGEST_ADLER32 - Static variable in class org.apache.cassandra.io.sstable.Component
-
- DIGEST_CRC32 - Static variable in class org.apache.cassandra.io.sstable.Component
-
- DIGEST_SHA1 - Static variable in class org.apache.cassandra.io.sstable.Component
-
- digestComponent - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
digest component - might be null
for old, legacy sstables
- digestFor(ChecksumType) - Static method in class org.apache.cassandra.io.sstable.Component
-
- DigestMismatchException - Exception in org.apache.cassandra.service
-
- DigestMismatchException(DecoratedKey, ByteBuffer, ByteBuffer) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
-
- DigestResolver - Class in org.apache.cassandra.service
-
- DigestResolver(Keyspace, ReadCommand, ConsistencyLevel, int) - Constructor for class org.apache.cassandra.service.DigestResolver
-
- digestVersion() - Method in class org.apache.cassandra.db.ReadCommand
-
If the query is a digest one, the requested digest version.
- DIGIT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- direction - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- direction - Variable in enum org.apache.cassandra.transport.Message.Type
-
- directories - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- Directories - Class in org.apache.cassandra.db
-
Encapsulate handling of paths to the data files.
- Directories(CFMetaData) - Constructor for class org.apache.cassandra.db.Directories
-
- Directories(CFMetaData, Collection<Directories.DataDirectory>) - Constructor for class org.apache.cassandra.db.Directories
-
- Directories(CFMetaData, Directories.DataDirectory[]) - Constructor for class org.apache.cassandra.db.Directories
-
Create Directories of given ColumnFamily.
- directories - Variable in class org.apache.cassandra.db.DiskBoundaries
-
- Directories.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(File) - Constructor for class org.apache.cassandra.utils.DirectorySizeCalculator
-
- dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- disable() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- disable() - Method in class org.apache.cassandra.db.compaction.CompactionLogger
-
- disable() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- DISABLE_THREAD_VALIDATION - Static variable in class org.apache.cassandra.gms.Gossiper.Props
-
- 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() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- DISABLED - Static variable in class org.apache.cassandra.utils.memory.BufferPool
-
- disableEarlyOpeningForTests - Static variable in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- DisableGossip - Class in org.apache.cassandra.tools.nodetool
-
- DisableGossip() - Constructor for class org.apache.cassandra.tools.nodetool.DisableGossip
-
- DisableHandoff - Class in org.apache.cassandra.tools.nodetool
-
- DisableHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.DisableHandoff
-
- disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- disableSnapshotOnDuplicateRowDetection() - Method in class org.apache.cassandra.service.StorageProxy
-
- disableSnapshotOnDuplicateRowDetection() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- DisableThrift - Class in org.apache.cassandra.tools.nodetool
-
- DisableThrift() - Constructor for class org.apache.cassandra.tools.nodetool.DisableThrift
-
- disableTombstoneCompactions - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- DisallowedDirectories - Class in org.apache.cassandra.db
-
- DisallowedDirectoriesMBean - Interface in org.apache.cassandra.db
-
- discard(CommitLogSegment, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
- discard(CommitLogSegment, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
-
- discardCompletedSegments(UUID, 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(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Discarder
-
- Discarder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
-
- DiscarderByIndex(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.DiscarderByIndex
-
- DiscarderByKey(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.DiscarderByKey
-
- 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.
- discoverComponentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
- disk_access_mode - Variable in class org.apache.cassandra.config.Config
-
- disk_failure_policy - Variable in class org.apache.cassandra.config.Config
-
- disk_optimization_estimate_percentile - Variable in class org.apache.cassandra.config.Config
-
- disk_optimization_page_cross_chance - Variable in class org.apache.cassandra.config.Config
-
- disk_optimization_strategy - Variable in class org.apache.cassandra.config.Config
-
- DiskBoundaries - Class in org.apache.cassandra.db
-
- DiskBoundaries(ColumnFamilyStore, Directories.DataDirectory[], int) - Constructor for class org.apache.cassandra.db.DiskBoundaries
-
- DiskBoundaries(ColumnFamilyStore, Directories.DataDirectory[], List<PartitionPosition>, long, int) - Constructor for class org.apache.cassandra.db.DiskBoundaries
-
- DiskBoundaryManager - Class in org.apache.cassandra.db
-
- DiskBoundaryManager() - Constructor for class org.apache.cassandra.db.DiskBoundaryManager
-
- diskHeadAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- DiskOptimizationStrategy - Interface in org.apache.cassandra.io.util
-
- diskTailAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- Dispatcher(boolean, Server.EndpointPayloadTracker) - Constructor for class org.apache.cassandra.transport.Message.Dispatcher
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlLexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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.config.SchemaConstants
-
- doAbort(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- doAbort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
undo all of the changes made by this transaction, resetting the state to its original form
- doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
-
- doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- doAbort(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
-
- doAbort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
-
- doAbort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- doAntiCompaction(UUID, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Submit anti-compaction jobs to CompactionManager.
- doCallbackOnFailure() - Method in class org.apache.cassandra.net.MessageIn
-
- doCommit(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- doCommit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
point of no return: commit all changes, but leave all readers marked as compacting
- doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
-
- doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- doCommit(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
-
- doCommit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
-
- doCommit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- doCompute() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- doFlush(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- doFlush(int) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
Merges this restriction with the specified TokenRestriction
.
- doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
-
- doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
-
- doneWithNonLocalSession(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- doOnClose(PartitionIterator, Runnable) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
-
Wraps the provided iterator to run a specified action on close.
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
perform an exception-safe post-abort cleanup
- doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
-
- doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
-
- doPreCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
perform an exception-safe pre-abort/commit cleanup;
this will be run after prepareToCommit (so before commit), and before abort
- doPrepare() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- doPrepare() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- doPrepare() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
-
- doPrepare() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- doPrepare() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- doPrepare() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- doPrepare() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
-
- doPrepare() - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
-
- doPrepare() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
Do any preparatory work prior to commit.
- doShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
- doShadowRound(Set<InetAddress>) - Method in class org.apache.cassandra.gms.Gossiper
-
Do a single 'shadow' round of gossip by retrieving endpoint states that will be stored exclusively in the
map return value, instead of endpointStateMap.
- DoubleSerializer - Class in org.apache.cassandra.serializers
-
- DoubleSerializer() - Constructor for class org.apache.cassandra.serializers.DoubleSerializer
-
- DoubleType - Class in org.apache.cassandra.db.marshal
-
- doVerb(MessageIn<UUID>, int) - Method in class org.apache.cassandra.batchlog.BatchRemoveVerbHandler
-
- doVerb(MessageIn<Batch>, int) - Method in class org.apache.cassandra.batchlog.BatchStoreVerbHandler
-
- doVerb(MessageIn<CounterMutation>, int) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
-
- doVerb(MessageIn<Collection<Mutation>>, int) - Method in class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.MigrationRequestVerbHandler
-
- doVerb(MessageIn<Mutation>, int) - Method in class org.apache.cassandra.db.MutationVerbHandler
-
- doVerb(MessageIn<ReadCommand>, int) - Method in class org.apache.cassandra.db.ReadCommandVerbHandler
-
- doVerb(MessageIn<Mutation>, int) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- doVerb(MessageIn<Truncation>, int) - Method in class org.apache.cassandra.db.TruncateVerbHandler
-
- doVerb(MessageIn<GossipDigestAck2>, int) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- doVerb(MessageIn<GossipDigestAck>, int) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- doVerb(MessageIn<GossipDigestSyn>, int) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- doVerb(MessageIn<HintMessage>, int) - Method in class org.apache.cassandra.hints.HintVerbHandler
-
- doVerb(MessageIn<T>, int) - Method in interface org.apache.cassandra.net.IVerbHandler
-
This method delivers a message to the implementing class (if the implementing
class was registered by a call to MessagingService.registerVerbHandlers).
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.net.ResponseVerbHandler
-
- doVerb(MessageIn<RepairMessage>, int) - Method in class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- doVerb(MessageIn<EchoMessage>, int) - Method in class org.apache.cassandra.service.EchoVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.PrepareVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.ProposeVerbHandler
-
- doVerb(MessageIn<SnapshotCommand>, int) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
-
- downsample(IndexSummary, int, int, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
Downsamples an existing index summary to a new sampling level.
- Downsampling - Class in org.apache.cassandra.io.sstable
-
- Downsampling() - Constructor for class org.apache.cassandra.io.sstable.Downsampling
-
- drain() - Method in class org.apache.cassandra.service.StorageService
-
Shuts node off to writes, empties memtables and the commit log.
- drain(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
makes node unavailable for writes, flushes memtables and replays commitlog.
- drain() - Method in class org.apache.cassandra.tools.NodeProbe
-
- Drain - Class in org.apache.cassandra.tools.nodetool
-
- Drain() - Constructor for class org.apache.cassandra.tools.nodetool.Drain
-
- driverType(AbstractType) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
Returns the Java Driver DataType
for the C* internal type.
- driverTypeFromAbstractType(String) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- driverTypes(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
Construct an array containing the Java Driver DataType
s for the
C* internal types.
- dropAggregate(UDAggregate) - Method in class org.apache.cassandra.config.Schema
-
- dropAggregateStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropAggregateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropAggregateStatement - Class in org.apache.cassandra.cql3.statements
-
A DROP AGGREGATE
statement parsed from a CQL query.
- DropAggregateStatement(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- dropCf(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- dropData(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- dropData(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
-
- dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
-
- dropFunction(UDFunction) - Method in class org.apache.cassandra.config.Schema
-
- dropFunctionStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropFunctionStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropFunctionStatement - Class in org.apache.cassandra.cql3.statements
-
A DROP FUNCTION
statement parsed from a CQL query.
- DropFunctionStatement(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropIndexStatement - Class in org.apache.cassandra.cql3.statements
-
- DropIndexStatement(IndexName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- dropKeyspace(String) - Method in class org.apache.cassandra.config.Schema
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- DropKeyspaceStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- dropMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropMaterializedViewStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DROPPABLE_SYSTEM_AUTH_TABLES - Static variable in class org.apache.cassandra.service.ClientState
-
- DROPPABLE_VERBS - Static variable in class org.apache.cassandra.net.MessagingService
-
Verbs it's okay to drop if the request has been queued longer than the request timeout.
- dropPageCache(long) - Method in class org.apache.cassandra.io.util.FileHandle
-
Drop page cache from start to given before
.
- dropped - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
Number of dropped messages
- DROPPED_COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- DroppedColumn(String, ColumnDefinition.Kind, AbstractType<?>, long) - Constructor for class org.apache.cassandra.config.CFMetaData.DroppedColumn
-
- droppedColumns(Map<ByteBuffer, CFMetaData.DroppedColumn>) - Method in class org.apache.cassandra.config.CFMetaData
-
- DroppedMessageMetrics - Class in org.apache.cassandra.metrics
-
Metrics for dropped messages by verb.
- DroppedMessageMetrics(MessagingService.Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
-
- DroppedMessageMetrics(MetricNameFactory) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
-
- droppedMutations - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Dropped Mutations Count
- droppedMutations - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- droppedTime - Variable in class org.apache.cassandra.config.CFMetaData.DroppedColumn
-
- dropRole(AuthenticatedUser, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- dropRole(AuthenticatedUser, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of DROP ROLE statement, as well we removing any main record of the role from the system
this implies that we want to revoke this role from all other roles that it has been granted to.
- dropRoleStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- DropRoleStatement(RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropRoleStatement
-
- dropSSTables() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- dropSSTables(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- dropSSTables(Predicate<SSTableReader>, OperationType, Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
removes all sstables that are not busy compacting.
- dropSSTablesIfInvalid(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- dropTable(String, String) - Method in class org.apache.cassandra.config.Schema
-
- dropTableStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropTableStatement - Class in org.apache.cassandra.cql3.statements
-
- DropTableStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTableStatement
-
- dropTriggerStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- DropTriggerStatement(CFName, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- dropType(UserType) - Method in class org.apache.cassandra.config.Schema
-
- dropTypeFromSchemaMutation(KeyspaceMetadata, UserType, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- dropTypeStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropTypeStatement - Class in org.apache.cassandra.cql3.statements
-
- DropTypeStatement(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- dropUserStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- dropUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- dropView(String, String) - Method in class org.apache.cassandra.config.Schema
-
- DropViewStatement - Class in org.apache.cassandra.cql3.statements
-
- DropViewStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropViewStatement
-
- dryRun() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
-
Only validate and prepare fix, but do not write updated (fixed) sstable serialization-headers.
- dryRun - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
-
- dst - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- DTEST_IS_IN_JVM_DTEST - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
-
- 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
-
- dumpReCreateStatements(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
- dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- duplicate() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- DUPLICATE_ROWS_DETECTED_SNAPSHOT_PREFIX - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- duplicateDirectByteBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- DuplicateRowChecker - Class in org.apache.cassandra.db.transform
-
- duplicateRows(CFMetaData, Iterable<InetAddress>) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- durableWrites - Variable in class org.apache.cassandra.schema.KeyspaceParams
-
- duration(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- DURATION - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DURATION - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DURATION - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DURATION - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- Duration - Class in org.apache.cassandra.cql3
-
Represents a duration.
- DURATION_ISO_8601_PERIOD_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DURATION_ISO_8601_PERIOD_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DURATION_ISO_8601_PERIOD_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DURATION_ISO_8601_PERIOD_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DURATION_ISO_8601_TIME_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DURATION_ISO_8601_TIME_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DURATION_ISO_8601_TIME_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DURATION_ISO_8601_TIME_DESIGNATORS - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DURATION_ISO_8601_WEEK_PERIOD_DESIGNATOR - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DURATION_ISO_8601_WEEK_PERIOD_DESIGNATOR - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DURATION_ISO_8601_WEEK_PERIOD_DESIGNATOR - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DURATION_ISO_8601_WEEK_PERIOD_DESIGNATOR - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DURATION_UNIT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- DURATION_UNIT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- DURATION_UNIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DURATION_UNIT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DurationSerializer - Class in org.apache.cassandra.serializers
-
- DurationSerializer() - Constructor for class org.apache.cassandra.serializers.DurationSerializer
-
- DurationType - Class in org.apache.cassandra.db.marshal
-
Represents a duration.
- duringCompaction(UnfilteredPartitionIterator, OperationType) - Static method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- duringRead(PartitionIterator, List<InetAddress>) - Static method in class org.apache.cassandra.db.transform.DuplicateRowChecker
-
- dynamic_snitch - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_badness_threshold - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_reset_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- DynamicCompositeType - Class in org.apache.cassandra.db.marshal
-
- DynamicEndpointSnitch - Class in org.apache.cassandra.locator
-
A dynamic snitch that sorts endpoints by latency with an adapted phi failure detector
- DynamicEndpointSnitch(IEndpointSnitch) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- DynamicEndpointSnitch(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- DynamicEndpointSnitchMBean - Interface in org.apache.cassandra.locator
-
- DynamicList<E> - Class in org.apache.cassandra.utils
-
- DynamicList(int) - Constructor for class org.apache.cassandra.utils.DynamicList
-
- DynamicList.Node<E> - Class in org.apache.cassandra.utils
-
- DynamicTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
-
- DynamicTokenTreeBuilder() - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- DynamicTokenTreeBuilder(TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- DynamicTokenTreeBuilder(SortedMap<Long, LongSet>) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- F - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- F - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- F - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- F - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- factor - Variable in class org.apache.cassandra.net.RateBasedBackPressure
-
- Factory() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Factory
-
- Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
-
- Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
-
- factory - Static variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
- factory - Static variable in class org.apache.cassandra.metrics.CompactionMetrics
-
- factory - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
- factory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
- Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer.Factory
-
- fail() - Method in class org.apache.cassandra.repair.Validator
-
Called when some error during the validation happened.
- failedRepairJob(UUID, String, String, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- failIfCanCast(Throwable, Class<T>) - Static method in class org.apache.cassandra.utils.Throwables
-
- failParentRepair(UUID, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- failRepairs(UUID, String, String[], Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- failure - Variable in class org.apache.cassandra.metrics.AuthMetrics
-
Number and rate of login failures
- FAILURE_CALLBACK_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
-
- FAILURE_REASON_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
-
- FAILURE_RESPONSE_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
-
- FailureDetector - Class in org.apache.cassandra.gms
-
This FailureDetector is an implementation of the paper titled
"The Phi Accrual Failure Detector" by Hayashibara.
- FailureDetector() - Constructor for class org.apache.cassandra.gms.FailureDetector
-
- FailureDetectorInfo - Class in org.apache.cassandra.tools.nodetool
-
- FailureDetectorInfo() - Constructor for class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
-
- FailureDetectorMBean - Interface in org.apache.cassandra.gms
-
- FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- failureReasonByEndpoint - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- failures - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- FastByteArrayInputStream - Class in org.apache.cassandra.io.util
-
A specialized InputStream
for reading the contents of a byte array.
- FastByteArrayInputStream(byte[]) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
.
- FastByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
with the initial position set to offset
and the
number of bytes available set to offset
+ length
.
- FastByteOperations - Class in org.apache.cassandra.utils
-
Utility code to do optimized byte-array comparison.
- FastByteOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations
-
- FastByteOperations.ByteOperations - Interface in org.apache.cassandra.utils
-
- FastByteOperations.PureJavaOperations - Class in org.apache.cassandra.utils
-
- FastByteOperations.UnsafeOperations - Class in org.apache.cassandra.utils
-
- FBUtilities - Class in org.apache.cassandra.utils
-
- FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
-
- fchannel - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- fdProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- fetchAsync() - Method in class org.apache.cassandra.dht.RangeStreamer
-
- fetchedCellIsQueried(ColumnDefinition, 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(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Tester
-
Must only be called if fetches(path) == true
.
- fetchedColumnIsQueried(ColumnDefinition) - 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.
- fetchedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
The columns that needs to be fetched internally for this filter.
- fetches(ColumnDefinition) - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
Whether the provided column is fetched by this filter.
- fetches(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Tester
-
- fetchesAllColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
- fetchNonSystemKeyspaces() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- fetchPage(int, ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
-
- fetchPage(int, ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
-
- fetchPage(int, ConsistencyLevel, ClientState, long) - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Fetches the next page.
- fetchPageInternal(int, ReadExecutionController) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
-
- fetchPageInternal(int, ReadExecutionController) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
-
- fetchPageInternal(int, ReadExecutionController) - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Fetches the next page internally (in other, this does a local query).
- fident() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- fident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- field - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
-
- FieldDeletion(ColumnDefinition.Raw, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.Operation.FieldDeletion
-
- FieldIdentifier - Class in org.apache.cassandra.cql3
-
Identifies a field in a UDT.
- FieldIdentifier(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.FieldIdentifier
-
- fieldName(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldNameAsString(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldNames() - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldPosition(FieldIdentifier) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fields - Variable in class org.apache.cassandra.serializers.TupleSerializer
-
- fields - Variable in class org.apache.cassandra.serializers.UserTypeSerializer
-
- fieldSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.UserTypes
-
- fieldType(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldTypes() - Method in class org.apache.cassandra.db.marshal.UserType
-
- fifteenMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
15m hit rate
- fifteenMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
15m hit rate
- fifteenMinuteRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Returns the 15-minute rate in terms of events per second.
- file - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- file_cache_round_up - Variable in class org.apache.cassandra.config.Config
-
Because of the current
BufferPool
slab sizes of 64 kb, we
store in the file cache buffers that divide 64 kb, so we need to round the buffer sizes to powers of two.
- file_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- FileDataInput - Interface in org.apache.cassandra.io.util
-
- fileDigestValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- FileDigestValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
-
- FileDirectSegment - Class in org.apache.cassandra.db.commitlog
-
Writes to the backing commit log file only on sync, allowing transformations of the mutations,
such as compression or encryption, before writing out to disk.
- fileEndPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
-
offset in file where this section ends.
- FileHandle - Class in org.apache.cassandra.io.util
-
- FileHandle.Builder - Class in org.apache.cassandra.io.util
-
Configures how the file will be read (compressed, mmapped, use cache etc.)
- fileLength - Variable in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- fileLength() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- fileLength() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- fileLength() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- fileLength() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
-
- FileMessageHeader - Class in org.apache.cassandra.streaming.messages
-
StreamingFileHeader is appended before sending actual data to describe what it's sending.
- FileMessageHeader(UUID, int, Version, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionInfo, long, int, SerializationHeader.Component) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- FileMessageHeader(UUID, int, Version, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionMetadata, long, int, SerializationHeader.Component) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fileName - Variable in enum org.apache.cassandra.db.compaction.OperationType
-
- filename(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- fileName - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- filePath() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- filePath - Variable in exception org.apache.cassandra.io.util.CorruptFileException
-
- files - Variable in class org.apache.cassandra.streaming.StreamSummary
-
Number of files to transfer.
- files - Variable in class org.apache.cassandra.streaming.StreamTransferTask
-
- 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
-
- fileSent(FileMessageHeader) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after sending FileMessageHeader.
- fileSeqNum - Variable in class org.apache.cassandra.streaming.StreamReader
-
- fileStartPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
-
offset in file where this section begins.
- FileUtils - Class in org.apache.cassandra.io.util
-
- filter() - Method in class org.apache.cassandra.batchlog.BatchlogManager.EndpointFilter
-
- filter - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- filter(UnfilteredPartitionIterator, int, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- filter(UnfilteredRowIterator, int, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- filter(PartitionIterator, int, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- filter(CFMetaData, int) - Method in class org.apache.cassandra.db.filter.RowFilter
-
- filter(UnfilteredPartitionIterator, int) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Filters the provided iterator so that only the row satisfying the expression of this filter
are included in the resulting iterator.
- filter(PartitionIterator, CFMetaData, int) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Filters the provided iterator so that only the row satisfying the expression of this filter
are included in the resulting iterator.
- filter(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
-
- filter(ColumnFilter, CFMetaData) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- filter(ColumnFilter, DeletionTime, boolean, CFMetaData) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- filter(ColumnFilter, DeletionTime, CFMetaData.DroppedColumn, LivenessInfo) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- filter(ColumnFilter, CFMetaData) - Method in interface org.apache.cassandra.db.rows.Row
-
Returns a copy of this row that:
1) only includes the data for the column included by filter
.
- filter(ColumnFilter, DeletionTime, boolean, CFMetaData) - Method in interface org.apache.cassandra.db.rows.Row
-
Returns a copy of this row that:
1) only includes the data for the column included by filter
.
- filter(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns a iterator that only returns rows with only live content.
- Filter - Class in org.apache.cassandra.db.transform
-
- Filter(int, boolean) - Constructor for class org.apache.cassandra.db.transform.Filter
-
- filter(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.transform.FilteredPartitions
-
Filter any RangeTombstoneMarker from the iterator's iterators, transforming it into a PartitionIterator.
- filter(UnfilteredPartitionIterator, Filter) - Static method in class org.apache.cassandra.db.transform.FilteredPartitions
-
- filter(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.transform.FilteredRows
-
Filter any RangeTombstoneMarker from the iterator, transforming it into a RowIterator.
- FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
-
- filter(Predicate<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces
-
- filterCipherSuites(String[], String[]) - Static method in class org.apache.cassandra.security.SSLFactory
-
- filteredEndpoints - Variable in class org.apache.cassandra.service.StorageProxy.RangeForQuery
-
- 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
-
- filterForQuery(Keyspace, List<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- filterForQuery(Keyspace, List<InetAddress>, ReadRepairDecision) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.CachedHashDecoratedKey
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.DecoratedKey
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.PreHashedDecoratedKey
-
- filterHash(long[]) - Method in interface org.apache.cassandra.utils.IFilter.FilterKey
-
Places the murmur3 hash of the key in the given long array of size at least two.
- 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
-
- filterPermissions(Set<Permission>, IResource) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- FilterPipelineBuilder - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Creates a Pipeline object for applying n pieces of logic
from the provided methods to the builder in a guaranteed order
- FilterPipelineBuilder(FilterPipelineTask<?, ?>) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
-
- FilterPipelineExecutor - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Executes all linked Pipeline Tasks serially and returns
output (if exists) from the executed logic
- FilterPipelineExecutor() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineExecutor
-
- FilterPipelineTask<F,T> - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
A single task or set of work to process an input
and return a single output.
- FilterPipelineTask() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
-
- filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Filters SSTables that are to be excluded from the given collection
- finalFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- 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, SerializationHeader) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- finalReader - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
-
- finalState - Variable in exception org.apache.cassandra.streaming.StreamException
-
- find(String) - Method in class org.apache.cassandra.db.Directories
-
- find(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.Functions
-
Find the function with the specified name
- find(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- findAll(String, String) - Static method in class org.apache.cassandra.db.view.View
-
- findBaseTable(String, String) - Static method in class org.apache.cassandra.db.view.View
-
- findBlockIndex(ClusteringBound, int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- findByIndex(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- findCorrectRange(Token) - Method in class org.apache.cassandra.repair.Validator
-
- findFunction(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.config.Schema
-
Find the function with the specified name
- findIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Honours result semantics of Arrays.binarySearch(long[], long)
, as though it were performed on the tree flattened into an array
- findIndexedTable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- findNested(Throwable) - Static method in error org.apache.cassandra.io.FSError
-
Unwraps the Throwable cause chain looking for an FSError instance
- findPositionOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
-
Finds the position of a shard with the given id within the context (via binary search).
- findSupportingVersion(CassandraVersion...) - Method in class org.apache.cassandra.utils.CassandraVersion
-
Returns a version that is backward compatible with this version amongst a list
of provided version, or null if none can be found.
- finish() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
we are done, return the finished sstables so that the caller can mark the old ones as compacted
- finish() - Method in interface org.apache.cassandra.index.Index.Indexer
-
Notification of the end of the partition update.
- finish() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- finish(Pair<ByteBuffer, ByteBuffer>, File, TermIterator) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- finish(File) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
Finishes up index building process by creating/populating index file.
- finish(Descriptor, File) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- finish(Descriptor, Pair<ByteBuffer, ByteBuffer>, File, TermIterator) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- finish() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- finish() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- finish() - Method in class org.apache.cassandra.index.sasi.sa.IntegralSA
-
- finish() - Method in class org.apache.cassandra.index.sasi.sa.SA
-
- finish() - Method in class org.apache.cassandra.index.sasi.sa.SuffixSA
-
- finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- finish(long, long, boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- finish(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- finish() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
Finishes the new file(s)
Creates final files, adds the new files to the Tracker (via replaceReader).
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- finish() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- finish() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
convenience method to both prepareToCommit() and commit() in one operation;
only of use to outer-most transactional object of an object graph
- finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
-
- finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.metrics.CompactionMetrics
-
- finishCompactionsAndShutdown(long, TimeUnit) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- finished() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- finished() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Open the resultant SSTableReader once it has been fully written, and all related state
is ready to be finalised including other sstables being written involved in the same operation
- finished() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- finished() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- finished() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- finishLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- finishLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- finishOnClose(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
-
- finishOnClose() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
-
- finishParentSession(UUID, Set<InetAddress>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Run final process of repair.
- finishSampling(int) - Method in class org.apache.cassandra.utils.TopKSampler
-
Call to stop collecting samples, and gather the results
- finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- finishTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- 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
- fireErrorAndComplete(String, int, int, String) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
-
- first - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- first() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- firstByteValueMask(int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
- firstEndpoint - Variable in class org.apache.cassandra.repair.SyncTask
-
- firstIteration - Variable in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
-
- firstKey() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
-
- firstKeyBeyond(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Finds and returns the first key beyond a given token in this SSTable or null if no such key exists.
- firstName - Variable in class org.apache.cassandra.io.sstable.IndexInfo
-
- firstNotCovered(Collection<IntervalSet<CommitLogPosition>>) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
Find the earliest commit log position that is not covered by the known flushed ranges for some table.
- firstToken(ArrayList<Token>, Token) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
- firstTokenIndex(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
- firstValue - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiEQRestriction
-
- firstValue - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiSliceRestriction
-
- fiveMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
5m hit rate
- fiveMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
5m hit rate
- fixedRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
-
- fixNonFrozenUDTIfUpgradeFrom30() - Static method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
-
- flags() - Method in class org.apache.cassandra.config.CFMetaData
-
- flags - Variable in class org.apache.cassandra.transport.Frame.Header
-
- flagsFromStrings(Set<String>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- flagsToStrings(Set<CFMetaData.Flag>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- floatingPoint(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- FloatSerializer - Class in org.apache.cassandra.serializers
-
- FloatSerializer() - Constructor for class org.apache.cassandra.serializers.FloatSerializer
-
- FloatType - Class in org.apache.cassandra.db.marshal
-
- floor(long) - Method in class org.apache.cassandra.io.util.MmappedRegions
-
- floor(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- floorIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- flow - Variable in class org.apache.cassandra.net.RateBasedBackPressure
-
- flush(int, int) - Method in class org.apache.cassandra.db.commitlog.FileDirectSegment
-
- flush(int, int) - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
-
- flush(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionLogger
-
- flush() - Method in class org.apache.cassandra.db.Keyspace
-
- flush() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- flush() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- flush() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- flush() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
-
- Flush - Class in org.apache.cassandra.tools.nodetool
-
- Flush() - Constructor for class org.apache.cassandra.tools.nodetool.Flush
-
- flushAllIndexesBlocking() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Perform a blocking flush all indexes
- flushAllNonCFSBackedIndexesBlocking() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Performs a blocking flush of all custom indexes
- flushAndFsyncBlockingly(Iterable<UUID>) - Method in class org.apache.cassandra.hints.HintsService
-
Flush the buffer pool for the selected target nodes, then fsync their writers.
- flushBeforeTransfer(boolean) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Set flushBeforeTransfer option.
- flushBuffer(ByteBuffer, DataOutputPlus, boolean) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- flushData() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- flushData() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- flushData() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Override this method instead of overriding flush()
- flushHistogram() - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramBuilder
-
Drain the temporary spool into the final bins
- flushIndexesBlocking(Set<Index>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Perform a blocking flush of selected indexes
- flushingMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
-
contains all memtables that are no longer referenced for writing and are queued for / in the process of being
flushed.
- flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
-
True if a cache flush is currently executing: only one may execute at a time.
- flushLargestMemtable() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Finds the largest memtable, as a percentage of *either* on- or off-heap memory limits, and immediately
queues it for flushing.
- flushRunnables(LifecycleTransaction) - Method in class org.apache.cassandra.db.Memtable
-
- fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- folderSize(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Get the size of a directory in bytes
- FOLLOW_186_in_relationType10714 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_alterTableStatement5147 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_alterTableStatement5314 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_cfamColumns4041 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_cfamDefinition3936 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_cfamProperty4158 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createAggregateStatement3019 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createFunctionStatement3452 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createIndexStatement4403 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createMaterializedViewStatement4696 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createMaterializedViewStatement4698 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createMaterializedViewStatement4744 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_createTypeStatement4285 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_dropAggregateStatement3265 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_dropFunctionStatement3683 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_function9657 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_function9691 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_functionResource7010 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_indexIdent4513 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_indexIdent4532 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_indexIdent4553 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_indexIdent4571 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_normalInsertStatement2004 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_normalInsertStatement2042 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_pkDef4088 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_relation10961 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_relation11169 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_selectionFunctionArgs1685 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_selectionFunctionArgs1697 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_singleColumnInValues11290 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_term9837 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_tupleLiteral9205 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_tupleOfIdentifiers11241 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_tupleOfMarkersForTuples11432 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_tupleOfTupleLiterals11346 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_unaliasedSelector1455 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_unaliasedSelector1488 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_unaliasedSelector1528 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_unaliasedSelector1568 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_187_in_unaliasedSelector1607 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_alterTableStatement5212 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_alterTableStatement5360 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_cfamColumns4058 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_cfamDefinition3952 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_cfamProperty4171 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createAggregateStatement3087 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createFunctionStatement3528 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createIndexStatement4419 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createMaterializedViewStatement4719 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createMaterializedViewStatement4734 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createMaterializedViewStatement4765 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_createTypeStatement4301 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_customIndexExpression1841 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_dropAggregateStatement3343 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_dropFunctionStatement3761 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_function9659 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_function9697 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_functionResource7088 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_indexIdent4519 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_indexIdent4538 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_indexIdent4559 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_indexIdent4577 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_normalInsertStatement2026 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_normalInsertStatement2063 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_pkDef4111 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_relation10963 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_relation11174 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_selectionFunctionArgs1687 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_selectionFunctionArgs1734 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_singleColumnInValues11316 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_term9843 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_tupleLiteral9226 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_tupleOfIdentifiers11260 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_tupleOfMarkersForTuples11451 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_tupleOfTupleLiterals11365 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_unaliasedSelector1461 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_unaliasedSelector1492 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_unaliasedSelector1534 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_unaliasedSelector1574 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_188_in_unaliasedSelector1619 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_189_in_normalColumnOperation9958 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_alterTableStatement5191 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_alterTableStatement5349 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_cfamColumns4047 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_cfamDefinition3943 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_cfamProperty4164 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_collection_type11922 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_collectionLiteral9028 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createAggregateStatement3059 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createFunctionStatement3496 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createIndexStatement4410 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createMaterializedViewStatement4708 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createMaterializedViewStatement4723 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createMaterializedViewStatement4754 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_createTypeStatement4292 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_customIndexExpression1835 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_deleteSelection2662 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_dropAggregateStatement3311 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_dropFunctionStatement3729 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_functionArgs9736 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_functionResource7056 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_mapLiteral8851 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_normalInsertStatement2015 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_normalInsertStatement2052 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_pkDef4100 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_selectClause1261 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_selectionFunctionArgs1717 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_selectStatement1128 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_selectStatement1156 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_setOrMapLiteral8921 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_setOrMapLiteral8966 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_singleColumnInValues11303 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_tuple_type12034 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_tupleLiteral9215 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_tupleOfIdentifiers11250 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_tupleOfMarkersForTuples11441 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_tupleOfTupleLiterals11355 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_updateStatement2404 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_191_in_usertypeLiteral9151 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_192_in_constant8783 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_columnCondition10386 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_columnFamilyName8239 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_columnOperationDifferentiator9928 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_deleteOp2742 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_functionName9471 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_indexName8200 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_unaliasedSelector1653 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_194_in_userTypeName8270 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_inMarker11205 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_inMarkerForTuple11482 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_intValue9408 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_jsonValue2240 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_mapLiteral8841 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_mapLiteral8857 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_markerForTuple11396 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_setOrMapLiteral8901 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_setOrMapLiteral8927 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_usertypeLiteral9141 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_usertypeLiteral9157 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_195_in_value9339 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_196_in_batchStatement2861 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_196_in_query80 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_197_in_collection_type11916 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_197_in_collection_type11948 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_197_in_collection_type11975 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_197_in_comparatorType11569 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_197_in_relationType10672 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_197_in_tuple_type12014 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_198_in_relationType10683 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_collectionColumnOperation10083 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_columnOperationDifferentiator9891 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_property10569 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_property10587 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_relationType10661 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_roleOption7680 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_roleOption7697 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_roleOption7714 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_roleOption7731 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_199_in_udtColumnOperation10113 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_collection_type11928 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_collection_type11954 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_collection_type11981 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_comparatorType11575 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_relationType10693 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_200_in_tuple_type12050 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_201_in_relationType10704 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_202_in_collectionLiteral9004 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_202_in_columnCondition10248 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_202_in_columnOperationDifferentiator9911 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_202_in_deleteOp2722 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_202_in_relation10911 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_203_in_selectClause1277 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_203_in_unaliasedSelector1490 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_204_in_collectionLiteral9048 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_204_in_columnCondition10254 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_204_in_columnOperationDifferentiator9917 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_204_in_deleteOp2728 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_204_in_relation10917 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_205_in_customIndexExpression1830 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_206_in_collectionLiteral9058 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_206_in_collectionLiteral9089 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_206_in_mapLiteral8821 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_206_in_usertypeLiteral9135 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_207_in_collectionLiteral9071 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_207_in_collectionLiteral9091 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_207_in_mapLiteral8877 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_207_in_usertypeLiteral9168 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_allowedFunctionName_in_createAggregateStatement3101 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_allowedFunctionName_in_createAggregateStatement3139 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_allowedFunctionName_in_functionName9477 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterKeyspaceStatement_in_cqlStatement427 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterMaterializedViewStatement_in_cqlStatement978 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterRoleStatement_in_cqlStatement827 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterTableStatement_in_cqlStatement403 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterTypeStatement_in_cqlStatement670 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_alterUserStatement_in_cqlStatement526 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_basic_unreserved_keyword_in_non_type_ident12185 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_basic_unreserved_keyword_in_unreserved_function_keyword12307 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_batchStatement_in_cqlStatement146 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_batchStatementObjective_in_batchStatement2859 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_BOOLEAN_in_constant8706 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_BOOLEAN_in_roleOption7718 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_BOOLEAN_in_roleOption7735 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamColumns_in_cfamDefinition3938 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamColumns_in_cfamDefinition3945 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamDefinition_in_createTableStatement3917 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamOrdering_in_cfamProperty4160 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamOrdering_in_cfamProperty4166 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamProperty_in_cfamDefinition3964 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamProperty_in_cfamDefinition3971 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamProperty_in_createMaterializedViewStatement4799 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfamProperty_in_createMaterializedViewStatement4806 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfisStatic_in_alterTableStatement5118 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfisStatic_in_alterTableStatement5162 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfisStatic_in_alterTableStatement5205 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cfName_in_columnFamilyName8243 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_columnCondition10150 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_columnOperation9870 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_createMaterializedViewStatement4702 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_createMaterializedViewStatement4712 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_createMaterializedViewStatement4727 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_createMaterializedViewStatement4748 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_createMaterializedViewStatement4758 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_deleteOp2693 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_deleteOp2720 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_deleteOp2740 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_groupByClause1904 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_indexIdent4483 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_indexIdent4517 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_indexIdent4536 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_indexIdent4557 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_indexIdent4575 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_normalColumnOperation10015 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_normalColumnOperation9962 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_normalColumnOperation9983 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_normalInsertStatement2008 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_normalInsertStatement2019 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_orderByClause1871 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10736 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10756 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10774 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10822 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10848 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10874 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_relation10909 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_tupleOfIdentifiers11245 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_tupleOfIdentifiers11254 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_unaliasedSelector1360 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_unaliasedSelector1532 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cident_in_unaliasedSelector1572 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_collection_type_in_comparatorType11527 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_collectionColumnOperation_in_columnOperationDifferentiator9919 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_collectionLiteral_in_value9271 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnCondition_in_updateConditions2485 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnCondition_in_updateConditions2492 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_alterMaterializedViewStatement5640 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_alterTableStatement5048 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_createIndexStatement4401 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_createMaterializedViewStatement4633 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_createMaterializedViewStatement4655 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_createTableStatement3907 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_createTriggerStatement4878 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_dataResource6811 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_deleteStatement2552 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_dropMaterializedViewStatement6132 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_dropTableStatement5974 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_dropTriggerStatement4949 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_insertStatement1935 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_selectStatement1092 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_truncateStatement6172 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnFamilyName_in_updateStatement2376 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnOperation_in_updateStatement2400 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnOperation_in_updateStatement2406 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_columnOperationDifferentiator_in_columnOperation9872 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTableStatement5073 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTableStatement5112 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTableStatement5157 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTableStatement5200 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTypeStatement5715 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_alterTypeStatement5741 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_cfamColumns4001 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_collection_type11920 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_collection_type11926 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_collection_type11952 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_collection_type11979 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_comparatorType11573 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createAggregateStatement3043 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createAggregateStatement3063 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createAggregateStatement3115 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createFunctionStatement3480 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createFunctionStatement3504 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_createFunctionStatement3571 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_dropAggregateStatement3293 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_dropAggregateStatement3315 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_dropFunctionStatement3711 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_dropFunctionStatement3733 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_functionResource7038 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_functionResource7060 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_term9841 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_tuple_type12029 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_tuple_type12038 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_typeColumns4325 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_comparatorType_in_unaliasedSelector1459 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_constant_in_propertyValue10616 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_constant_in_value9249 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_cqlStatement_in_query77 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createAggregateStatement_in_cqlStatement763 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createFunctionStatement_in_cqlStatement721 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createIndexStatement_in_cqlStatement308 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createKeyspaceStatement_in_cqlStatement264 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createMaterializedViewStatement_in_cqlStatement952 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createRoleStatement_in_cqlStatement803 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createTableStatement_in_cqlStatement285 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createTriggerStatement_in_cqlStatement602 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createTypeStatement_in_cqlStatement646 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_createUserStatement_in_cqlStatement502 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_customIndexExpression_in_relationOrExpression1802 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dataResource_in_resource6713 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_deleteOp_in_deleteSelection2647 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_deleteOp_in_deleteSelection2666 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_deleteSelection_in_deleteStatement2535 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_deleteStatement_in_batchStatementObjective2934 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_deleteStatement_in_cqlStatement176 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropAggregateStatement_in_cqlStatement782 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropFunctionStatement_in_cqlStatement741 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropIndexStatement_in_cqlStatement378 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropKeyspaceStatement_in_cqlStatement331 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropMaterializedViewStatement_in_cqlStatement964 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropRoleStatement_in_cqlStatement852 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropTableStatement_in_cqlStatement353 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropTriggerStatement_in_cqlStatement623 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropTypeStatement_in_cqlStatement695 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_dropUserStatement_in_cqlStatement551 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_DURATION_in_constant8725 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_EMPTY_QUOTED_NAME_in_cident7793 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_EOF_in_query84 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_fident_in_alterTypeStatement5709 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_alterTypeStatement5737 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_alterTypeStatement5802 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_alterTypeStatement5808 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_alterTypeStatement5835 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_alterTypeStatement5841 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_columnCondition10390 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_columnOperationDifferentiator9932 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_deleteOp2746 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_typeColumns4321 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_unaliasedSelector1657 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_usertypeLiteral9139 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_fident_in_usertypeLiteral9155 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_FLOAT_in_constant8685 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_function_in_term9805 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionArgs_in_function9695 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_createAggregateStatement3011 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_createFunctionStatement3444 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_dropAggregateStatement3247 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_dropFunctionStatement3665 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_function9655 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_function9689 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_functionResource6992 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionName_in_unaliasedSelector1634 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_functionResource_in_resource6737 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_grantPermissionsStatement_in_cqlStatement448 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_grantRoleStatement_in_cqlStatement903 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_groupByClause_in_selectStatement1123 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_groupByClause_in_selectStatement1130 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_HEXNUMBER_in_constant8765 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_allowedFunctionName9504 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_cfamColumns3997 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_cfamColumns4051 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_cfamOrdering4199 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_cfName8407 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_cident7808 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_createFunctionStatement3585 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_createTriggerStatement4863 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_dropTriggerStatement4942 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_fident8016 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_ident7947 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_idxName8483 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_ksName8331 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_non_type_ident12129 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_noncol_ident8086 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_pkDef4078 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_pkDef4094 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ident_in_pkDef4104 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_roleName8559 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_schema_cident7877 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_IDENT_in_username12069 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_idxName_in_createIndexStatement4392 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_idxName_in_customIndexExpression1832 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_idxName_in_indexName8204 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_indexIdent_in_createIndexStatement4406 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_indexIdent_in_createIndexStatement4412 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_indexName_in_dropIndexStatement6074 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_inMarker_in_columnCondition10220 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_inMarker_in_columnCondition10340 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_inMarker_in_columnCondition10476 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_inMarker_in_relation10828 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_inMarkerForTuple_in_relation10995 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_insertStatement_in_batchStatementObjective2908 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_insertStatement_in_cqlStatement88 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_INTEGER_in_alterTableStatement5394 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_INTEGER_in_constant8666 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_INTEGER_in_intValue9394 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_INTEGER_in_normalColumnOperation10019 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_intValue_in_selectStatement1183 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_intValue_in_selectStatement1202 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_intValue_in_usingClauseDelete2772 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_intValue_in_usingClauseObjective2324 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_intValue_in_usingClauseObjective2338 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_jmxResource_in_resource6749 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_jsonInsertStatement_in_insertStatement1968 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_jsonValue_in_jsonInsertStatement2138 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ADD_in_alterTableStatement5092 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ADD_in_alterTypeStatement5731 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AGGREGATE_in_createAggregateStatement2984 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AGGREGATE_in_dropAggregateStatement3221 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_dataResource6772 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_functionResource6949 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_functionResource6961 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_jmxResource6840 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_permissionOrAll6656 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALL_in_roleResource6899 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALLOW_in_selectStatement1217 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterKeyspaceStatement4989 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterMaterializedViewStatement5632 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterRoleStatement7475 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterTableStatement5042 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterTableStatement5062 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterTypeStatement5685 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterTypeStatement5705 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ALTER_in_alterUserStatement7232 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_alterTableStatement5533 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_alterTypeStatement5831 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_cfamDefinition3969 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_createMaterializedViewStatement4804 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_properties10542 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_roleOptions7654 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_updateConditions2490 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_usingClause2296 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AND_in_whereClause1769 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_APPLY_in_batchStatement2875 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AS_in_createFunctionStatement3593 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AS_in_createMaterializedViewStatement4635 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AS_in_selector1313 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_AS_in_unaliasedSelector1613 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ASC_in_cfamOrdering4202 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ASC_in_orderByClause1874 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ASCII_in_native_type11622 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BATCH_in_batchStatement2835 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BATCH_in_batchStatement2877 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BEGIN_in_batchStatement2806 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BIGINT_in_native_type11636 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BLOB_in_native_type11649 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BOOLEAN_in_native_type11664 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BY_in_cfamProperty4156 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BY_in_selectStatement1121 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_BY_in_selectStatement1149 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CALLED_in_createFunctionStatement3547 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CAST_in_unaliasedSelector1600 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CLUSTERING_in_cfamProperty4152 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COLUMNFAMILY_in_alterTableStatement5044 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COLUMNFAMILY_in_createTableStatement3885 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COLUMNFAMILY_in_dataResource6802 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COLUMNFAMILY_in_dropTableStatement5960 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COLUMNFAMILY_in_truncateStatement6166 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COMPACT_in_alterTableStatement5234 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COMPACT_in_cfamProperty4140 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CONTAINS_in_relation10876 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COUNT_in_allowedFunctionName9608 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COUNT_in_unaliasedSelector1486 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COUNTER_in_batchStatement2822 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_COUNTER_in_native_type11676 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createAggregateStatement2967 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createFunctionStatement3400 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createIndexStatement4360 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createKeyspaceStatement3820 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createMaterializedViewStatement4614 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createRoleStatement7402 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createTableStatement3883 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createTriggerStatement4844 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createTypeStatement4245 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CREATE_in_createUserStatement7136 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_CUSTOM_in_createIndexStatement4363 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DATE_in_native_type11870 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DECIMAL_in_native_type11688 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DEFAULT_in_jsonInsertStatement2148 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DELETE_in_deleteStatement2529 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DESC_in_cfamOrdering4206 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DESC_in_orderByClause1878 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DISTINCT_in_selectStatement1069 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DOUBLE_in_native_type11700 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_alterTableStatement5232 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_alterTableStatement5269 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropAggregateStatement3219 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropFunctionStatement3637 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropIndexStatement6058 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropKeyspaceStatement5908 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropMaterializedViewStatement6114 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropRoleStatement7537 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropTableStatement5958 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropTriggerStatement4925 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropTypeStatement6008 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DROP_in_dropUserStatement7326 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_DURATION_in_native_type11713 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ENTRIES_in_indexIdent4551 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createAggregateStatement2997 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createFunctionStatement3430 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createIndexStatement4376 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createKeyspaceStatement3829 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createMaterializedViewStatement4625 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createRoleStatement7411 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createTableStatement3892 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createTriggerStatement4853 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createTypeStatement4254 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_createUserStatement7145 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_deleteStatement2592 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropAggregateStatement3232 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropFunctionStatement3650 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropIndexStatement6065 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropKeyspaceStatement5915 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropMaterializedViewStatement6123 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropRoleStatement7544 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropTableStatement5965 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropTriggerStatement4932 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropTypeStatement6015 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_dropUserStatement7333 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_jsonInsertStatement2180 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_normalInsertStatement2077 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_EXISTS_in_updateStatement2435 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FILTERING_in_selectStatement1219 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FINALFUNC_in_createAggregateStatement3133 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FLOAT_in_native_type11726 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROM_in_createMaterializedViewStatement4651 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROM_in_deleteStatement2548 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROM_in_revokePermissionsStatement6322 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROM_in_revokeRoleStatement6456 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROM_in_selectStatement1088 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FROZEN_in_comparatorType11567 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FULL_in_indexIdent4569 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FUNCTION_in_createFunctionStatement3417 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FUNCTION_in_dropFunctionStatement3639 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FUNCTION_in_functionResource6988 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FUNCTIONS_in_functionResource6951 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_FUNCTIONS_in_functionResource6963 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_GRANT_in_grantPermissionsStatement6197 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_GRANT_in_grantRoleStatement6367 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_GROUP_in_selectStatement1119 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createAggregateStatement2993 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createFunctionStatement3426 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createIndexStatement4372 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createKeyspaceStatement3825 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createMaterializedViewStatement4621 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createRoleStatement7407 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createTableStatement3888 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createTriggerStatement4849 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createTypeStatement4250 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_createUserStatement7141 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_deleteStatement2588 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropAggregateStatement3230 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropFunctionStatement3648 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropIndexStatement6063 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropKeyspaceStatement5913 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropMaterializedViewStatement6121 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropRoleStatement7542 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropTableStatement5963 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropTriggerStatement4930 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropTypeStatement6013 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_dropUserStatement7331 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_jsonInsertStatement2176 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_normalInsertStatement2073 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IF_in_updateStatement2431 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_columnCondition10182 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_columnCondition10294 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_columnCondition10430 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_functionResource6965 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_relation10824 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_relation10850 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IN_in_relation10947 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INDEX_in_createIndexStatement4369 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INDEX_in_dropIndexStatement6060 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INET_in_native_type11740 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INITCOND_in_createAggregateStatement3166 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INPUT_in_createFunctionStatement3557 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INSERT_in_insertStatement1929 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INT_in_native_type11755 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_INTO_in_insertStatement1931 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_IS_in_relation10776 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_JSON_in_insertStatement1964 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_JSON_in_selectStatement1052 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEY_in_cfamColumns4025 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEY_in_cfamColumns4039 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEY_in_createMaterializedViewStatement4684 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEY_in_non_type_ident12197 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEY_in_relation10881 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYS_in_indexIdent4530 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACE_in_alterKeyspaceStatement4991 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACE_in_createKeyspaceStatement3822 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACE_in_dataResource6784 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement5910 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACE_in_functionResource6967 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_KEYSPACES_in_dataResource6774 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LANGUAGE_in_createFunctionStatement3579 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIKE_in_relation10758 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIMIT_in_selectStatement1179 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIMIT_in_selectStatement1198 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIST_in_collection_type11946 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIST_in_listPermissionsStatement6508 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIST_in_listRolesStatement7592 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LIST_in_listUsersStatement7366 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_LOGIN_in_roleOption7729 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MAP_in_collection_type11913 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MATERIALIZED_in_alterMaterializedViewStatement5634 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MATERIALIZED_in_createMaterializedViewStatement4616 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MATERIALIZED_in_dropMaterializedViewStatement6116 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MBEAN_in_jmxResource6862 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MBEANS_in_jmxResource6842 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_MBEANS_in_jmxResource6874 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NORECURSIVE_in_listPermissionsStatement6563 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NORECURSIVE_in_listRolesStatement7619 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOSUPERUSER_in_alterUserStatement7280 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOSUPERUSER_in_createUserStatement7187 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createAggregateStatement2995 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createFunctionStatement3428 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createIndexStatement4374 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createKeyspaceStatement3827 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createMaterializedViewStatement4623 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createRoleStatement7409 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createTableStatement3890 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createTriggerStatement4851 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createTypeStatement4252 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_createUserStatement7143 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_jsonInsertStatement2178 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_normalInsertStatement2075 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NOT_in_relation10778 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NULL_in_createFunctionStatement3541 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NULL_in_createFunctionStatement3555 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NULL_in_jsonInsertStatement2152 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NULL_in_relation10780 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_NULL_in_value9315 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_OF_in_listPermissionsStatement6547 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_OF_in_listRolesStatement7604 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_createFunctionStatement3553 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_createIndexStatement4397 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_createTriggerStatement4874 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_dropTriggerStatement4945 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_grantPermissionsStatement6217 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_listPermissionsStatement6530 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ON_in_revokePermissionsStatement6302 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_OPTIONS_in_roleOption7695 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_OR_in_createAggregateStatement2970 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_OR_in_createFunctionStatement3403 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ORDER_in_cfamProperty4154 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ORDER_in_selectStatement1147 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PARTITION_in_selectStatement1177 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PASSWORD_in_roleOption7678 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PASSWORD_in_userPassword7757 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PER_in_selectStatement1175 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PERMISSION_in_permissionOrAll6685 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PERMISSIONS_in_permissionOrAll6660 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PRIMARY_in_cfamColumns4023 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PRIMARY_in_cfamColumns4037 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_PRIMARY_in_createMaterializedViewStatement4682 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_RENAME_in_alterTableStatement5452 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_RENAME_in_alterTypeStatement5764 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_REPLACE_in_createAggregateStatement2972 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_REPLACE_in_createFunctionStatement3405 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_RETURNS_in_createFunctionStatement3539 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_RETURNS_in_createFunctionStatement3565 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_REVOKE_in_revokePermissionsStatement6282 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_REVOKE_in_revokeRoleStatement6434 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLE_in_alterRoleStatement7477 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLE_in_createRoleStatement7404 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLE_in_dropRoleStatement7539 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLE_in_roleResource6911 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLES_in_listRolesStatement7594 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_ROLES_in_roleResource6901 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SELECT_in_createMaterializedViewStatement4645 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SELECT_in_selectStatement1042 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SET_in_collection_type11972 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SET_in_updateStatement2398 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SFUNC_in_createAggregateStatement3095 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SMALLINT_in_native_type11771 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_STATIC_in_cfamColumns4006 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_STATIC_in_cfisStatic5596 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_STORAGE_in_alterTableStatement5236 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_STORAGE_in_cfamProperty4142 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_STYPE_in_createAggregateStatement3109 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SUPERUSER_in_alterUserStatement7266 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SUPERUSER_in_createUserStatement7181 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_SUPERUSER_in_roleOption7712 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TEXT_in_native_type11782 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIME_in_native_type11885 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIMESTAMP_in_alterTableStatement5390 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIMESTAMP_in_native_type11797 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIMESTAMP_in_usingClauseDelete2768 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIMESTAMP_in_usingClauseObjective2320 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TIMEUUID_in_native_type11859 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TINYINT_in_native_type11807 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_alterTableStatement5508 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_alterTableStatement5539 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_alterTypeStatement5804 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_alterTypeStatement5837 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_grantPermissionsStatement6237 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TO_in_grantRoleStatement6389 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TOKEN_in_allowedFunctionName9576 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TOKEN_in_relation10790 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TRIGGER_in_createTriggerStatement4846 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TRIGGER_in_dropTriggerStatement4927 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TRUNCATE_in_truncateStatement6163 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TTL_in_unaliasedSelector1560 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TTL_in_usingClauseObjective2334 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TUPLE_in_tuple_type12012 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TYPE_in_alterTableStatement5069 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TYPE_in_alterTypeStatement5687 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TYPE_in_alterTypeStatement5711 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TYPE_in_createTypeStatement4247 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_TYPE_in_dropTypeStatement6010 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_UNLOGGED_in_batchStatement2816 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_UNSET_in_jsonInsertStatement2160 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_UPDATE_in_updateStatement2372 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USE_in_useStatement1004 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USER_in_alterUserStatement7234 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USER_in_createUserStatement7138 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USER_in_dropUserStatement7328 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USERS_in_listUsersStatement7368 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USING_in_alterTableStatement5388 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USING_in_createIndexStatement4430 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USING_in_createTriggerStatement4880 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USING_in_usingClause2289 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_USING_in_usingClauseDelete2766 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_UUID_in_native_type11819 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VALUES_in_indexIdent4511 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VALUES_in_normalInsertStatement2034 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VARCHAR_in_native_type11834 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VARINT_in_native_type11846 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VIEW_in_alterMaterializedViewStatement5636 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VIEW_in_createMaterializedViewStatement4618 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_VIEW_in_dropMaterializedViewStatement6118 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WHERE_in_createMaterializedViewStatement4666 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WHERE_in_deleteStatement2574 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WHERE_in_selectStatement1102 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WHERE_in_updateStatement2417 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_alterKeyspaceStatement5005 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_alterMaterializedViewStatement5652 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_alterRoleStatement7491 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_alterTableStatement5416 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_alterUserStatement7250 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_cfamDefinition3962 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_createIndexStatement4449 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_createKeyspaceStatement3846 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_createMaterializedViewStatement4797 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_createRoleStatement7429 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WITH_in_createUserStatement7165 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_K_WRITETIME_in_unaliasedSelector1526 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_alterKeyspaceStatement4995 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_createKeyspaceStatement3838 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_dataResource6790 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_dropKeyspaceStatement5924 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_functionName9469 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_functionResource6973 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_keyspaceName_in_useStatement1008 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ksName_in_columnFamilyName8236 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ksName_in_indexName8197 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_ksName_in_keyspaceName8163 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_listPermissionsStatement_in_cqlStatement483 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_listRolesStatement_in_cqlStatement878 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_listUsersStatement_in_cqlStatement577 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_mapLiteral_in_property10591 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_mapLiteral_in_roleOption7701 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_markerForTuple_in_relation11139 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_markerForTuple_in_tupleOfMarkersForTuples11436 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_markerForTuple_in_tupleOfMarkersForTuples11445 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_mbean_in_jmxResource6864 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_mbean_in_jmxResource6876 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_native_type_in_comparatorType11511 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_native_type_in_unaliasedSelector1617 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_native_type_in_unreserved_function_keyword12319 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_non_type_ident_in_userTypeName8276 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_createFunctionStatement3476 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_createFunctionStatement3500 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_inMarker11209 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_inMarkerForTuple11486 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_intValue9412 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_jsonValue2244 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_markerForTuple11400 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_property10567 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_property10585 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_selector1317 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_userTypeName8268 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_noncol_ident_in_value9343 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_normalColumnOperation_in_columnOperationDifferentiator9893 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_normalInsertStatement_in_insertStatement1949 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_orderByClause_in_selectStatement1151 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_orderByClause_in_selectStatement1158 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_permission_in_permissionOrAll6681 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_permissionOrAll_in_grantPermissionsStatement6209 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_permissionOrAll_in_listPermissionsStatement6520 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_permissionOrAll_in_revokePermissionsStatement6294 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_pkDef_in_cfamColumns4043 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_properties_in_alterKeyspaceStatement5007 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_properties_in_alterMaterializedViewStatement5654 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_properties_in_alterTableStatement5419 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_properties_in_createIndexStatement4451 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_properties_in_createKeyspaceStatement3848 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_property_in_cfamProperty4131 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_property_in_properties10538 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_property_in_properties10544 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_propertyValue_in_property10573 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_cfName8461 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_idxName8537 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_inMarker11195 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_inMarkerForTuple11472 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_intValue9423 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_jsonValue2258 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_ksName8385 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_markerForTuple11386 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_roleName8629 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QMARK_in_value9354 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_allowedFunctionName9538 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_cfName8432 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_cident7833 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_fident8041 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_ident7972 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_idxName8508 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_ksName8356 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_non_type_ident12160 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_noncol_ident8111 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_roleName8600 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_schema_cident7902 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_QUOTED_NAME_in_username12085 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relation_in_relation11171 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relation_in_relationOrExpression1793 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationOrExpression_in_whereClause1765 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationOrExpression_in_whereClause1771 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_columnCondition10164 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_columnCondition10272 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_columnCondition10408 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_relation10740 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_relation10798 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_relation10921 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_relation11105 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_relationType_in_relation11135 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_resource_in_grantPermissionsStatement6229 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_resource_in_listPermissionsStatement6532 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_resource_in_revokePermissionsStatement6314 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_revokePermissionsStatement_in_cqlStatement466 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_revokeRoleStatement_in_cqlStatement928 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleName_in_listPermissionsStatement6549 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleName_in_listRolesStatement7606 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleName_in_userOrRoleName8308 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleOption_in_roleOptions7650 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleOption_in_roleOptions7656 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleOptions_in_alterRoleStatement7493 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleOptions_in_createRoleStatement7431 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_roleResource_in_resource6725 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5066 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5107 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5152 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5195 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5284 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5319 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5353 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5506 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5512 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5537 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_schema_cident_in_alterTableStatement5543 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selectClause_in_createMaterializedViewStatement4649 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selectClause_in_selectStatement1078 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selectionFunctionArgs_in_unaliasedSelector1638 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selector_in_selectClause1256 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selector_in_selectClause1265 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_selectStatement_in_cqlStatement59 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_basic_unreserved_keyword12357 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_constant8792 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_normalColumnOperation9987 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_permission6599 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_shorthandColumnOperation10047 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_set_in_unreserved_keyword12256 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_setOrMapLiteral_in_collectionLiteral9066 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_shorthandColumnOperation_in_columnOperationDifferentiator9902 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_singleColumnInValues_in_columnCondition10200 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_singleColumnInValues_in_columnCondition10316 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_singleColumnInValues_in_columnCondition10452 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_singleColumnInValues_in_relation10854 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_comparatorType11593 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_constant8654 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_createFunctionStatement3599 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_createIndexStatement4434 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_createTriggerStatement4884 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_jsonValue2230 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_mbean12104 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_roleName8584 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_roleOption7684 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_username12077 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_STRING_LITERAL_in_userPassword7761 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_collectionColumnOperation10087 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_collectionLiteral9022 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_collectionLiteral9032 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_collectionLiteral9062 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_columnCondition10168 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_columnCondition10252 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_columnCondition10276 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_columnCondition10412 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_columnOperationDifferentiator9915 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_createAggregateStatement3172 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_customIndexExpression1839 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_deleteOp2726 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_functionArgs9730 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_functionArgs9740 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_mapLiteral8839 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_mapLiteral8845 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_mapLiteral8855 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_mapLiteral8861 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_normalColumnOperation9955 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_normalColumnOperation9997 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_normalInsertStatement2046 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_normalInsertStatement2056 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10744 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10762 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10802 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10897 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10915 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_relation10925 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_setOrMapLiteral8905 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_setOrMapLiteral8925 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_setOrMapLiteral8931 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_setOrMapLiteral8970 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_shorthandColumnOperation10057 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_singleColumnInValues11298 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_singleColumnInValues11307 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_term9847 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_tupleLiteral9209 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_tupleLiteral9219 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_udtColumnOperation10117 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_usertypeLiteral9145 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_term_in_usertypeLiteral9161 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_truncateStatement_in_cqlStatement237 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tuple_type_in_comparatorType11539 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleLiteral_in_relation11109 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleLiteral_in_tupleOfTupleLiterals11350 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleLiteral_in_tupleOfTupleLiterals11359 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleLiteral_in_value9299 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleOfIdentifiers_in_relation10794 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleOfIdentifiers_in_relation10937 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleOfMarkersForTuples_in_relation11063 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_tupleOfTupleLiterals_in_relation11029 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_typeColumns_in_createTypeStatement4287 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_typeColumns_in_createTypeStatement4294 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_udtColumnOperation_in_columnOperationDifferentiator9934 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unaliasedSelector_in_selectionFunctionArgs1701 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unaliasedSelector_in_selectionFunctionArgs1721 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unaliasedSelector_in_selector1310 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unaliasedSelector_in_unaliasedSelector1611 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_function_keyword_in_allowedFunctionName9566 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_function_keyword_in_unreserved_keyword12240 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_cfName8451 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_cident7852 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_fident8060 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_ident7991 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_idxName8527 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_ksName8375 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_noncol_ident8130 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_propertyValue10638 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_roleName8619 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_unreserved_keyword_in_schema_cident7921 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_updateConditions_in_deleteStatement2600 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_updateConditions_in_updateStatement2443 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_updateStatement_in_batchStatementObjective2921 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_updateStatement_in_cqlStatement117 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_username_in_alterUserStatement7238 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_username_in_createUserStatement7153 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_username_in_dropUserStatement7341 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_alterRoleStatement7481 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_createRoleStatement7419 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_dropRoleStatement7552 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_grantPermissionsStatement6251 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_grantRoleStatement6381 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_grantRoleStatement6403 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_revokePermissionsStatement6336 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_revokeRoleStatement6448 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_revokeRoleStatement6470 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userOrRoleName_in_roleResource6917 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userPassword_in_alterUserStatement7252 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userPassword_in_createUserStatement7167 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usertypeLiteral_in_value9284 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userTypeName_in_alterTypeStatement5691 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userTypeName_in_comparatorType11555 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userTypeName_in_createTypeStatement4272 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_userTypeName_in_dropTypeStatement6024 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_useStatement_in_cqlStatement205 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClause_in_batchStatement2839 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClause_in_jsonInsertStatement2195 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClause_in_normalInsertStatement2092 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClause_in_updateStatement2386 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClauseDelete_in_deleteStatement2562 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClauseObjective_in_usingClause2291 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_usingClauseObjective_in_usingClause2298 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_UUID_in_constant8743 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_value_in_term9768 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_value_in_unaliasedSelector1408 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_value_in_unaliasedSelector1465 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_whereClause_in_createMaterializedViewStatement4670 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_whereClause_in_deleteStatement2578 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_whereClause_in_selectStatement1106 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- FOLLOW_whereClause_in_updateStatement2421 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- force(MappedByteBuffer) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- force(FileChannel, boolean) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- FORCE_3_0_PROTOCOL_VERSION - Static variable in class org.apache.cassandra.net.MessagingService
-
- force_new_prepared_statement_behaviour - Variable in class org.apache.cassandra.config.Config
-
- forceBatchlogReplay() - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- forceBatchlogReplay() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
-
Forces batchlog replay.
- forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceBlockingFlush(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- forceBlockingFlush() - Method in class org.apache.cassandra.db.view.TableViews
-
- forceBlockingFlush(String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- forceCleanup(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceCompactionForTokenRange(Collection<Range<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceCompactionForTokenRange(Collection<Range<Token>>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Forces a major compaction of specified token ranges in this column family.
- 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.
- forceConviction(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- forceConviction(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
force conviction of endpoint in the failure detector
- forcedProtocolVersion - Variable in class org.apache.cassandra.transport.Message
-
- forceFilterFailures() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
For testing purposes only.
- forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Flush if there is unflushed data in the memtables
- forceFlush(CommitLogPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
- forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- forceKeyspaceCleanup(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCleanup(PrintStream, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCompaction(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compaction of a single keyspace
- forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compaction of specified token range in a single keyspace.
- forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
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
-
- forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceMajorCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceMajorCompaction(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
force a major compaction of this column family
- forceNewerGeneration() - Method in class org.apache.cassandra.gms.Gossiper
-
- forceRecycleAllSegments(Iterable<UUID>) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
- forceRecycleAllSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
- forceRemoveCompletion() - Method in class org.apache.cassandra.service.StorageService
-
Force a remove operation to complete.
- forceRemoveCompletion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Force a remove operation to finish.
- forceRemoveCompletion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, RepairOption, boolean) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceShutdown() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Shutdowns both compaction and validation executors, cancels running compaction / validation,
and waits for tasks to complete if tasks were not cancelable.
- forceShutdown(Throwable) - Method in class org.apache.cassandra.repair.RepairSession
-
clear all RepairJobs and terminate this session.
- 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
-
- forColumn(ColumnDefinition) - Static method in class org.apache.cassandra.config.ColumnDefinition.Raw
-
Creates a ColumnDefinition.Raw
from a pre-existing ColumnDefinition
(useful in the rare cases where we already have the column but need
a ColumnDefinition.Raw
for typing purposes).
- forColumn(AbstractType<?>, ColumnIndex) - Static method in class org.apache.cassandra.index.sasi.memory.MemIndex
-
- forColumns(CFMetaData, List<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.Selection
-
- forExternalCalls(SocketAddress) - Static method in class org.apache.cassandra.service.ClientState
-
- forGroupByInternalPaging(GroupingState) - Method in class org.apache.cassandra.db.filter.DataLimits
-
Creates a DataLimits
instance to be used for paginating internally GROUP BY queries.
- forInternalCalls(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- forInternalCalls(List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.ClientState
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
-
- 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.
- format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- format - Variable in class org.apache.cassandra.io.sstable.format.Version
-
- format - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable format
- format - Variable in class org.apache.cassandra.streaming.StreamReader
-
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- formatType - Variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
- formatType - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- formatType() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
-
- forName(String) - Static method in enum org.apache.cassandra.schema.CompactionParams.TombstoneOption
-
- forPaging(AbstractBounds<PartitionPosition>, ClusteringComparator, Clustering, boolean) - Method in class org.apache.cassandra.db.DataRange
-
Returns a new DataRange
for use when paging this
range.
- forPaging(ClusteringComparator, Clustering, boolean) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
Returns a filter for continuing the paging of this filter given the last returned clustering prefix.
- forPaging(ClusteringComparator, Clustering, boolean) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- forPaging(ClusteringComparator, Clustering, boolean) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- forPaging(int) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- forPaging(int, ByteBuffer, int) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- forPaging(Clustering, DataLimits) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Returns a new command suitable to paging from the last returned row.
- forPaging(ClusteringComparator, Clustering, boolean, boolean) - Method in class org.apache.cassandra.db.Slice
-
Returns a slice for continuing paging from the last returned clustering prefix.
- forPaging(ClusteringComparator, Clustering, boolean, boolean) - Method in class org.apache.cassandra.db.Slices
-
Returns slices for continuing the paging of those slices given the last returned clustering prefix.
- 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.config.ColumnDefinition.Raw
-
Creates a ColumnDefinition.Raw
from a quoted identifier string.
- forQuoted(String) - Static method in class org.apache.cassandra.cql3.FieldIdentifier
-
Creates a FieldIdentifier
from a quoted identifier string.
- forShortReadRetry(int) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- forStatement(int) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- forSubRange(AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.db.DataRange
-
Returns a new DataRange
equivalent to this
one but restricted to the provided sub-range.
- forSubRange(AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- forSubRange(AbstractBounds<PartitionPosition>, boolean) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
Returns an equivalent command but that only queries data within the provided range.
- forTable(CFMetaData) - Method in class org.apache.cassandra.db.view.ViewManager
-
- forTable(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The schema (CREATE TABLE statement) for the table for which sstable are to be created.
- forThrift(int) - Static method in class org.apache.cassandra.db.filter.RowFilter
-
- forThrift(int, List<ColumnSpecification>) - Static method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- forTokenRange(Range<Token>) - Static method in class org.apache.cassandra.db.DataRange
-
Creates a DataRange
to query all rows over the provided token range.
- forUnquoted(String) - Static method in class org.apache.cassandra.config.ColumnDefinition.Raw
-
Creates a ColumnDefinition.Raw
from an unquoted identifier string.
- forUnquoted(String) - Static method in class org.apache.cassandra.cql3.FieldIdentifier
-
Creates a FieldIdentifier
from an unquoted identifier string.
- FORWARD_FROM - Static variable in class org.apache.cassandra.db.Mutation
-
- FORWARD_TO - Static variable in class org.apache.cassandra.db.Mutation
-
- ForwardingVersionedSerializer<T> - Class in org.apache.cassandra.io
-
A serializer which forwards all its method calls to another serializer.
- ForwardingVersionedSerializer() - Constructor for class org.apache.cassandra.io.ForwardingVersionedSerializer
-
- forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- forwardMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
-
- Frame - Class in org.apache.cassandra.transport
-
- Frame.Compressor - Class in org.apache.cassandra.transport
-
- Frame.Decoder - Class in org.apache.cassandra.transport
-
- Frame.Decompressor - Class in org.apache.cassandra.transport
-
- Frame.Encoder - Class in org.apache.cassandra.transport
-
- Frame.Header - Class in org.apache.cassandra.transport
-
- Frame.Header.Flag - Enum in org.apache.cassandra.transport
-
- FrameCompressor - Interface in org.apache.cassandra.transport
-
- FrameCompressor.LZ4Compressor - Class in org.apache.cassandra.transport
-
- FrameCompressor.SnappyCompressor - Class in org.apache.cassandra.transport
-
- free() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- free() - Method in class org.apache.cassandra.io.util.Memory
-
- free() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- free(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- 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
-
- from(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- from(String) - Static method in class org.apache.cassandra.cql3.Duration
-
Converts a String
into a duration.
- from(Collection<ColumnDefinition>) - Static method in class org.apache.cassandra.db.Columns
-
Returns a new Columns
object holing the same columns than the provided set.
- from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- from(String, String, String, Map.Entry<String, Pair<Long, Long>>, TabularDataSupport) - Static method in class org.apache.cassandra.db.SnapshotDetailsTabularData
-
- from - Variable in class org.apache.cassandra.net.IncomingTcpConnection
-
- from - Variable in class org.apache.cassandra.net.MessageIn
-
- from - Variable in class org.apache.cassandra.net.MessageOut
-
- from - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- 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.TableStatsPrinter
-
- from(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter
-
- fromByte(byte) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
- fromByte(byte) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- fromBytes(ByteBuffer, int, DecoratedKey) - 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
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- fromException(Throwable) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- fromException(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- fromExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- fromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fromFileName(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
- fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Component
-
Filename of the form "<ksname>/<cfname>-[tmp-][<version>-]<gen>-<component>",
- fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(String, SSTableFormat.Type) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(File, String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
Filename of the form is vary by version:
<ksname>-<cfname>-(tmp-)?<version>-<gen>-<component> for cassandra 2.0 and before
(<tmp marker>-)?<version>-<gen>-<component> for cassandra 3.0 and later
If this is for SSTable of secondary index, directory should ends with index name for 2.1+.
- fromHeader(File, EncryptionContext) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fromId(int) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- fromIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- fromIndexTargets(CFMetaData, 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(CFMetaData, DecoratedKey, Row) - Static method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- fromIterator(UnfilteredRowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Turns the given iterator into an update.
- fromIterator(RowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Turns the given iterator into an update.
- fromIteratorExplicitColumns(UnfilteredRowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- FromJsonFct - Class in org.apache.cassandra.cql3.functions
-
- fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Given a parsed JSON string, return a byte representation of the object.
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DurationType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ListType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LongType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.MapType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SetType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- fromKeyExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
-
- fromKeyIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
-
- fromLegacyMetadata(CFMetaData, ColumnDefinition, String, IndexMetadata.Kind, Map<String, String>) - Static method in class org.apache.cassandra.schema.IndexMetadata
-
- fromMap(Map<String, Object>, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
-
- fromMap(Map<String, Object>, boolean, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
-
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CachingParams
-
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
-
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
-
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.ReplicationParams
-
- 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
-
- fromPre30Iterator(UnfilteredRowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Removes duplicate rows from incoming iterator, to be used when we can't trust the underlying iterator (like when reading legacy sstables)
- fromRepresentation(String) - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
- fromRowIterator(RowIterator) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- fromSchemaMetadata(String, IndexMetadata.Kind, Map<String, String>) - Static method in class org.apache.cassandra.schema.IndexMetadata
-
- fromSelectors(CFMetaData, List<RawSelector>, VariableSpecifications, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
-
- fromSerialized(ByteBuffer, ListType, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.Lists.Value
-
- fromSerialized(ByteBuffer, MapType, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.Maps.Value
-
- fromSerialized(ByteBuffer, SetType, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.Sets.Value
-
- fromSerialized(ByteBuffer, ListType, QueryOptions) - Static method in class org.apache.cassandra.cql3.Tuples.InValue
-
- fromSerialized(ByteBuffer, TupleType) - Static method in class org.apache.cassandra.cql3.Tuples.Value
-
- fromSerialized(ByteBuffer, UserType) - Static method in class org.apache.cassandra.cql3.UserTypes.Value
-
- fromString(String) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.Type
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a byte representation of the given string.
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DurationType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.LongType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- fromString(String) - Static method in class org.apache.cassandra.io.sstable.format.VersionAndType
-
- fromString(String) - Static method in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- fromThrift(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(String, String, AbstractType<?>, AbstractType<?>, ColumnDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThriftForUpdate(CfDef, CFMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromType(AbstractType, ProtocolVersion) - Static method in enum org.apache.cassandra.transport.DataType
-
- fromUnfilteredRowIterator(ReadCommand, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- 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
-
- frozen(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- FrozenType - Class in org.apache.cassandra.db.marshal
-
A fake type that is only used for parsing type strings that include frozen types.
- FrozenType() - Constructor for class org.apache.cassandra.db.marshal.FrozenType
-
- FSDiskFullWriteError - Error in org.apache.cassandra.io
-
- FSDiskFullWriteError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSDiskFullWriteError
-
- FSError - Error in org.apache.cassandra.io
-
- FSError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
-
- FSErrorHandler - Interface in org.apache.cassandra.io
-
Interface for handling file system errors.
- FSReadError - Error in org.apache.cassandra.io
-
- FSReadError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSReadError
-
- FSReadError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSReadError
-
- FSWriteError - Error in org.apache.cassandra.io
-
- FSWriteError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSWriteError
-
- FSWriteError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSWriteError
-
- fullCollection(ColumnDefinition.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
-
- fullPartitionDelete(CFMetaData, DecoratedKey, long, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates an immutable partition update that entirely deletes a given partition.
- fullPartitionDelete(CFMetaData, ByteBuffer, long, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates a partition update that entirely deletes a given partition.
- fullPartitionRead(CFMetaData, int, DecoratedKey) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command that queries a single partition in its entirety.
- fullPartitionRead(CFMetaData, int, ByteBuffer) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command that queries a single partition in its entirety.
- fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
-
The top level range that this MerkleTree covers.
- FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- fullyQualified - Variable in class org.apache.cassandra.cql3.statements.CFStatement
-
- fullyQualified - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- function(String, String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Creates a FunctionResource representing a specific, keyspace-scoped function.
- function() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- function() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Function - Interface in org.apache.cassandra.cql3.functions
-
- function - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
-
- functionArgs() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- functionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
-
- FunctionCall - Class in org.apache.cassandra.cql3.functions
-
- FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
-
- FunctionExecutionException - Exception in org.apache.cassandra.exceptions
-
- FunctionExecutionException(FunctionName, List<String>, String) - Constructor for exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- functionFromCql(String, String, List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Creates a FunctionResource representing a specific, keyspace-scoped function.
- functionName() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- functionName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- FunctionName - Class in org.apache.cassandra.cql3.functions
-
- FunctionName(String, String) - Constructor for class org.apache.cassandra.cql3.functions.FunctionName
-
- functionName - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- FunctionResolver - Class in org.apache.cassandra.cql3.functions
-
- FunctionResource - Class in org.apache.cassandra.auth
-
IResource implementation representing functions.
- functionResource() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- functionResource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- functions - Variable in class org.apache.cassandra.index.internal.CassandraIndex
-
- Functions - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's UDAs and UDFs (and, in case of
SystemKeyspace
,
native functions and aggregates).
- functions - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
-
- FUNCTIONS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Functions.Builder - Class in org.apache.cassandra.schema
-
- G - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- G - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- G - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- G - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- garbageCollect(CompactionParams.TombstoneOption, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- garbageCollect(String, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- garbageCollect(String, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Rewrites all sstables from the given tables to remove deleted data.
- garbageCollect(String, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- garbageCollect(PrintStream, String, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GarbageCollect - Class in org.apache.cassandra.tools.nodetool
-
- GarbageCollect() - Constructor for class org.apache.cassandra.tools.nodetool.GarbageCollect
-
- GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- gc_log_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
-
- gc_warn_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
-
- gcBefore(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- gcBefore - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- gcBefore - Variable in class org.apache.cassandra.repair.Validator
-
- gceRegion - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- gceZone - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- gcGraceSeconds(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- gcGraceSeconds - Variable in class org.apache.cassandra.schema.TableParams
-
- GCInspector - Class in org.apache.cassandra.service
-
- GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
-
- GCInspectorMXBean - Interface in org.apache.cassandra.service
-
- gcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- gCql - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- gCql - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- GcStats - Class in org.apache.cassandra.tools.nodetool
-
- GcStats() - Constructor for class org.apache.cassandra.tools.nodetool.GcStats
-
- GE - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
-
- generate() - Static method in class org.apache.cassandra.utils.CounterId
-
- generateLegacyCfId(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
Generates deterministic UUID from keyspace/columnfamily name pair.
- generateViewUpdates(Collection<View>, UnfilteredRowIterator, UnfilteredRowIterator, int, boolean) - Method in class org.apache.cassandra.db.view.TableViews
-
Given some updates on the base table of this object and the existing values for the rows affected by that update, generates the
mutation to be applied to the provided views.
- generateViewUpdates() - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
-
- GENERATION - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
Generation is used as a timestamp for automatic table creation on startup.
- generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- GENERATION - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
Generation is used as a timestamp for automatic table creation on startup.
- GENERATION - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
-
Generation is used as a timestamp for automatic table creation on startup.
- generationReverseComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- GENSALT_LOG2_ROUNDS_PROPERTY - Static variable in class org.apache.cassandra.auth.CassandraRoleManager
-
- get(K) - Method in class org.apache.cassandra.auth.AuthCache
-
- get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- get(K) - Method in interface org.apache.cassandra.cache.ICache
-
- get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- get(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- get() - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
-
This is called when scheduling the task, and also before calling
ExecutorLocal.set(Object)
when running on a
executor thread.
- get(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Constants.Value
-
- get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Lists.Value
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Maps.Value
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Sets.Value
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Tuples.InValue
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Tuples.Value
-
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.UserTypes.Value
-
- get(int) - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
-
- get(int) - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Retrieves the ith value of this prefix.
- get(boolean, boolean) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
-
- get(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- get(CFMetaData) - Method in class org.apache.cassandra.db.Mutation
-
- get(int) - Method in class org.apache.cassandra.db.NativeClustering
-
- get(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.PartitionPosition.ForKey
-
- get(int) - Method in class org.apache.cassandra.db.rows.CellPath
-
- get() - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
-
- get(int) - Method in class org.apache.cassandra.db.Slices
-
Returns the ith slice of this Slices
object.
- get() - Method in class org.apache.cassandra.index.sasi.disk.Token
-
- get(long, Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
-
- get(String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentPrefixTrie
-
- get(String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentSuffixTrie
-
- get() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- get() - Method in interface org.apache.cassandra.index.sasi.utils.CombinedValue
-
- get() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- get(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- get(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
Get a snitch property value or return defaultValue if not defined.
- get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
-
- get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- get(FunctionName) - Method in class org.apache.cassandra.schema.Functions
-
Get all function overloads with the specified name
- get(String) - Method in class org.apache.cassandra.schema.Indexes
-
Get the index with the specified name
- get(UUID) - Method in class org.apache.cassandra.schema.Indexes
-
Get the index with the specified id
- get(String) - Method in class org.apache.cassandra.schema.Tables
-
Get the table with the specified name
- get(String) - Method in class org.apache.cassandra.schema.Triggers
-
Get the trigger with the specified name
- get(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
-
Get the type with the specified name
- get(String) - Method in class org.apache.cassandra.schema.Views
-
Get the materialized view with the specified name
- get() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
wait for an answer.
- get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- get() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- get() - Method in class org.apache.cassandra.service.ClientWarn
-
- get() - Method in class org.apache.cassandra.service.ReadCallback
-
- get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- get(byte) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get() - Method in class org.apache.cassandra.tracing.Tracing
-
- get(UUID) - Method in class org.apache.cassandra.tracing.Tracing
-
- get(InetAddress) - Static method in class org.apache.cassandra.transport.Server.EndpointPayloadTracker
-
- get(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
The converse of indexOf: provided an index between 0 and size, returns the i'th item, in set order.
- get(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- get() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- get(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- get(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- get(int) - Method in class org.apache.cassandra.utils.DynamicList
-
- get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- get(int) - Method in class org.apache.cassandra.utils.LockedDynamicList
-
- get(int) - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
- get(int, BufferType) - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
- get(List<? extends Iterator<In>>, Comparator<? super In>, MergeIterator.Reducer<In, Out>) - Static method in class org.apache.cassandra.utils.MergeIterator
-
- get(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
For testing purposes.
- get(Token) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get the MerkleTree.Range responsible for the given token.
- get(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
Returns true or false for the specified bit index.
- get(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- get(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true or false for the specified bit index.
- get(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true or false for the specified bit index.
- get(long, TimeUnit) - Method in class org.apache.cassandra.utils.RecomputingSupplier
-
- get(long, TimeUnit) - Method in class org.apache.cassandra.utils.SlidingTimeRate
-
Gets the current rate in the given time unit from the beginning of the time window to the
provided point in time ago.
- get(TimeUnit) - Method in class org.apache.cassandra.utils.SlidingTimeRate
-
Gets the current rate in the given time unit.
- get() - Method in class org.apache.cassandra.utils.Wrapped
-
- get() - Method in class org.apache.cassandra.utils.WrappedBoolean
-
- get() - Method in class org.apache.cassandra.utils.WrappedInt
-
- get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_multi_slice(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getActiveContentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveContentSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getActiveOnDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveOnDiskSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveRepairedSSTableRefsForAntiCompaction(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Get the still active sstables we should run anticompaction on
note that validation and streaming do not call this method - they have to work on the actual active sstables on the node, we only call this
to know which sstables are still there that were there when we started the repair
- getActiveSegmentCompressionRatios() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveSegmentCompressionRatios() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveSegments() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
- getAddress(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a milliseconds-since-epoch value for a type-1 UUID.
- getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getAllColumnFilter() - Method in class org.apache.cassandra.config.CFMetaData
-
- getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAllDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
-
- getAllDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the list of all data file locations from conf
- getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getAllFilePaths() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getAllIndexColumnFamilyStores() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAllMembers() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getAllMemtables() - Method in class org.apache.cassandra.db.lifecycle.View
-
- getAllocatedSize() - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
-
- getAllocateTokensForKeyspace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAllocator() - Method in class org.apache.cassandra.db.Memtable
-
- getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
-
Get all ranges that span the ring given a set
of tokens.
- getAllReplicationOptions() - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- getAllRoles() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getAllRoles() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during the execution of an unqualified LIST ROLES query.
- getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getAllSSTables(SSTableSet) - Method in class org.apache.cassandra.db.Keyspace
-
- getAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getAltVersion() - Method in class org.apache.cassandra.config.Schema
-
The "alternative" schema version, compatible to 3.0, always excludes the
cdc
column.
- getAnalyzer() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getAnalyzer(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds type information from @param bb to @param sb.
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- 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
-
- getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
-
- getApplicationState(InetAddress, ApplicationState) - Method in class org.apache.cassandra.gms.Gossiper
-
The value for the provided application state for the provided endpoint as currently known by this Gossip instance.
- getApproximateKeyCount(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Calculate approximate key count.
- getArchiveCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchiveCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Command to execute to archive a commitlog segment.
- getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getArray() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
- getArray() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
-
- getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
You should almost never use this.
- getAsClustering(CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyBound
-
- getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
-
- getAttachment(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getAuthenticatedUser() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
-
Following a sucessful negotiation, get the AuthenticatedUser representing the logged in subject.
- getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAvailableIndexName(String, String, String) - Static method in class org.apache.cassandra.schema.Indexes
-
- getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAvailableRanges(String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getAvailableRanges(String, IPartitioner) - Method in class org.apache.cassandra.dht.StreamStateStore
-
- getAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- getAverageIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getAverageIndexInterval() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getAvgColumnSetPerRow() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBackgroundCompactionTaskSubmitter() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getBackingFiles() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getBackingTable() - Method in interface org.apache.cassandra.index.Index
-
If the index implementation uses a local table to store its index data this method should return a
handle to it.
- getBackingTable() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getBackingTable() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getBackPressurePerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getBackPressurePerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Back-pressure rate limiting per host
- getBackPressureRateLimit() - Method in interface org.apache.cassandra.net.BackPressureState
-
Gets the current back-pressure rate limit.
- getBackPressureState() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getBackPressureStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
-
- getBackupsDirectory(File) - Static method in class org.apache.cassandra.db.Directories
-
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getBaseColumn(ColumnDefinition) - Method in class org.apache.cassandra.db.view.View
-
The base column corresponding to the provided view column.
- getBaseTableMetadataAsCQL(CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
- getBatchlogReplayThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchlogTimeout() - Static method in class org.apache.cassandra.batchlog.BatchlogManager
-
- getBatchSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchSizeFailThresholdInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchSizeFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getBatchSizeFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for rejecting queries due to a large batch size
- getBatchSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBestIndexFor(RowFilter) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Called at query time to choose which (if any) of the registered index implementations to use for a given query.
- getBestIndexFor(RowFilter.Expression) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
-
- getBlob(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBlock(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
-
- getBlock() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerTerm
-
- getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- getBlockIndex() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- getBlockingFlushTask() - Method in interface org.apache.cassandra.index.Index
-
Return a task which performs a blocking flush of the index's data to persistent storage.
- getBlockingFlushTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getBlockingFlushTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the amount of memory in bytes used off heap by the bloom filter.
- getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getBootstrapTokens(TokenMetadata, InetAddress, int) - Static method in class org.apache.cassandra.dht.BootStrapper
-
if initialtoken was specified, use that (split on comma).
- getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getBoundTerms() - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Returns the number of bound terms in this statement.
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- getBoundVariables() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- getBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBroadcastAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getBroadcastRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBroadcastRpcAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getBuckets(Collection<Pair<T, Long>>, double, double, long) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getBuckets(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getBuffer(int) - Method in class org.apache.cassandra.io.util.ThreadLocalByteBufferHolder
-
Returns the buffer for the current thread.
- getBufferPoolUseHeapIfExhausted() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBuildTaskSupport() - Method in interface org.apache.cassandra.index.Index
-
Get an instance of a helper to provide tasks for building the index from a set of SSTable data.
- getBuildTaskSupport() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of the names of the built column indexes for current store
- getBuiltIndexes(String, Set<String>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getBuiltIndexNames() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getByAddress(byte[]) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByAddress(InetAddress) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByAddressOverrideDefaults(InetAddress, Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByAddressOverrideDefaults(InetAddress, byte[], Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByName(String) - Method in class org.apache.cassandra.db.view.ViewManager
-
- getByName(String) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByNameOverrideDefaults(String, Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getByte(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getByte(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- 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(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBytes() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
- getBytes() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
-
- getBytes() - Method in class org.apache.cassandra.index.sasi.sa.IndexedTerm
-
- getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
- getBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getBytesRead() - Method in interface org.apache.cassandra.io.util.BytesReadTracker
-
- getBytesRead() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- getBytesRead() - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
- getBytesScanned() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getBytesScanned() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getBytesScanned() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getCacheCrcPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCacheDataPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCachedCounter(ByteBuffer, Clustering, ColumnDefinition, CellPath) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCachedPosition(KeyCacheKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCachedReplicaRowsFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCachedReplicaRowsFailThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getCachedReplicaRowsFailThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the number of rows cached at the coordinator before filtering/index queries fail outright.
- getCachedReplicaRowsWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCachedReplicaRowsWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getCachedReplicaRowsWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the number of rows cached at the coordinator before filtering/index queries log a warning.
- getCacheKey(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCacheLoadTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getCassandraServer() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getCDCDiskCheckInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCDCLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCDCSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCDCState() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getCell(ColumnDefinition) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- getCell(ColumnDefinition, CellPath) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- getCell(CellPath) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- getCell(ColumnDefinition) - Method in interface org.apache.cassandra.db.rows.Row
-
Returns a cell for a simple column.
- getCell(ColumnDefinition, 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
-
- getCF(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getCFDirectories() - Method in class org.apache.cassandra.db.Directories
-
- getCfId() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- getCfId() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- getCfId() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
-
Given a keyspace name and column family name, get the column family
meta data.
- getCFMetaData(UUID) - Method in class org.apache.cassandra.config.Schema
-
Get ColumnFamily metadata by its identifier
- getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
-
- getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCFMetadataAsCQL(CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
Build a CQL String representation of Column Family Metadata
- getCfName() - Method in class org.apache.cassandra.cql3.IndexName
-
- getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getChannel() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- getChannel() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getCheckForDuplicateRowsDuringCompaction() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCheckForDuplicateRowsDuringCompaction() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCheckForDuplicateRowsDuringReads() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCheckForDuplicateRowsDuringReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getChunkLength() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getChunksForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getClientAddress() - Method in class org.apache.cassandra.service.QueryState
-
- getClientEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClientFromInputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientFromOutputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientState() - Method in class org.apache.cassandra.service.QueryState
-
- getClientTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getClockAndCountOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the clock and the count associated with the given counter id, or (0, 0) if no such shard is present.
- getClosingString() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Bounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Range
-
- getCluster(String[], Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getClusteringColumns(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the requested clustering columns.
- getClusteringColumnsBounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the bounds (start or end) of the clustering columns.
- getClusteringTypes() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClusterName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the name of the cluster
- getClusterName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the name of the cluster
- getClusterName() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCmd(String) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getCollectionElementValue() - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getColumnCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- getColumnDefinition(ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns the ColumnDefinition for name
.
- getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinition(CFMetaData, ColumnDefinition.Raw) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
Retrieves the ColumnDefinition
corresponding to the specified raw ColumnIdentifier
.
- getColumnDefinitionForCQL(ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionForCQL(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionNameComparator(ColumnDefinition.Kind) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- getColumnDefs() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns the column definitions in position order.
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getColumnFamilies() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.Mutation
-
- getColumnFamilyMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve ColumnFamily metrics
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Deprecated.
- getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStore(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStoreIncludingIndexes(Pair<String, String>) - Method in class org.apache.cassandra.config.Schema
-
Retrieve a CFS by name even if that CFS is an index
An index is identified by looking for '.' in the CF name and separating to find the base table
containing the index
- getColumnFamilyStoreInstance(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFilter(CFMetaData, QueryOptions, SuperColumnCompatibility.SuperColumnRestrictions) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
For _dense_ SuperColumn Families, the supercolumn key column has to be translated to the collection subselection
query in order to avoid reading an entire collection and then filtering out the results.
- getColumnIndex(ColumnDefinition) - 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
-
- getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getColumnMapping() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getColumnMetadata() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.statements.AlterTableStatementColumn
-
- 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.ColumnConditions
-
- getColumns() - Method in interface org.apache.cassandra.cql3.Conditions
-
Returns the column definitions to which apply the conditions.
- getColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getColumnsInCommons(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
Returns the names of the columns that are specified within this Restrictions
and the other one
as a comma separated String
.
- getColumnSpecification(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Returns the column specification corresponding to the output value of the selector instances created by
this factory.
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Returns the column specifications for the bound variables (optional operation).
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- getColumnSpecifications() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
-
- getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getColumnType() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatementColumn
-
- getCommitFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the commit log
- getCommitLogLowerBound() - Method in class org.apache.cassandra.db.Memtable
-
- getCommitLogMaxCompressionBuffersInPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Maximum number of buffers in the compression pool.
- getCommitLogPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.Allocation
-
- getCommitLogSegmentSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
size of commitlog segments to allocate
- getCommitLogSync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSyncBatchWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSyncPeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogUpperBound() - Method in class org.apache.cassandra.db.Memtable
-
- getCompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionTask
-
- getCompactionHistory() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactionHistory() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
compaction history
- getCompactionHistory() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getCompactionHistory() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionInfo() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.view.ViewBuilder
-
- getCompactionInfo() - Method in class org.apache.cassandra.index.internal.CollatedViewIndexBuilder
-
- getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- getCompactionLargePartitionWarningThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getCompactionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getCompactionParametersJson() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionParametersJson() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getCompactionParams() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactions() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction objects.
- getCompactions() - Static method in class org.apache.cassandra.metrics.CompactionMetrics
-
- getCompactionStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
return the compaction strategy for the given sstable
returns differently based on the repaired status and which vnode the compaction strategy belongs to
- getCompactionStrategyManager() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionSummary() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactionSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction summary strings.
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- GetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
-
- GetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
-
- getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
-
- getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getCompactValueColumn(PartitionColumns) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
- getCompactValueColumn(PartitionColumns) - Static method in class org.apache.cassandra.db.CompactTables
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds DynamicCompositeType type information from @param bb1 to @param bb2.
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- getComparatorSerializedSize() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCompletedMesssages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getCompletedTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getComplex(int) - Method in class org.apache.cassandra.db.Columns
-
Returns the ith complex column of this object.
- getComplexColumnData(ColumnDefinition) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- getComplexColumnData(ColumnDefinition) - Method in interface org.apache.cassandra.db.rows.Row
-
The data for a complex column.
- getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- getComponent() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getComponents(CFMetaData, DecoratedKey) - Static method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getComponents() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Return a list of the "subcomponents" this type has.
- getComponents() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getCompressedLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the compression metadata for this sstable.
- getCompressionMetadataOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the amount of memory in bytes used off heap by the compression meta-data.
- getCompressionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the compression parameters
- getCompressionParametersJson() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionParametersJson() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getCompressionRatio() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCompressor() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor used to compress the segments.
- getCompressor() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getCompressor() - Method in class org.apache.cassandra.transport.Connection
-
- getCompressorClass() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor class.
- getCompressorName() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor name.
- getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentCompactors() - Method in class org.apache.cassandra.service.StorageService
-
- getConcurrentCompactors() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getConcurrentCompactors() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetConcurrentCompactors - Class in org.apache.cassandra.tools.nodetool
-
- GetConcurrentCompactors() - Constructor for class org.apache.cassandra.tools.nodetool.GetConcurrentCompactors
-
- getConcurrentCounterWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentViewWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConfiguration(JobContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke getConfiguration() on JobContext.
- getConnectedClients() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- getConnectedClients() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- getConnectedClients() - Method in class org.apache.cassandra.transport.Server
-
- getConnection(InetAddress, MessageOut) - Method in class org.apache.cassandra.net.MessagingService
-
- getConnectionFactory() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Provides connection factory.
- getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getContactedReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
Get the replicas involved in the [finished] request.
- getContactedReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor.NeverSpeculatingReadExecutor
-
- getCoreCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of compaction thread pool
- getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Returns core pool size of thread pool.
- getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of validation thread pool
- getCorrectDiskForSSTable(SSTableReader) - Method in class org.apache.cassandra.db.DiskBoundaries
-
- getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCount() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
-
- getCount() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxCounterMBean
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getCounter(TaskInputOutputContext, String, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke getCounter() on TaskInputOutputContext.
- getCounter(Enum<?>) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getCounter(String, String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getCounterCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getCounterCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getCounterCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getCounterCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getCounterCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCounterWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCounterWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCounterWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getCounterWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
-
- getCrcCheckChance() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getCrcCheckChance() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
-
Needed for tests.
- getCrcCheckChance() - Method in class org.apache.cassandra.schema.CompressionParams
-
- getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCredentialsCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCredentialsUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCredentialsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCurrent() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- getCurrent() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
- getCurrentCommitLogPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
-
- getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return the generation value for this node.
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCurrentMemtable() - Method in class org.apache.cassandra.db.lifecycle.View
-
- getCurrentMemtable() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getCurrentPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getCurrentPosition() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- getCurrentStat() - Method in class org.apache.cassandra.repair.SyncTask
-
- getCurrentState() - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- getCurrentStreams() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getCurrentStreams() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
Returns the current state of all ongoing streams.
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCustomIndexExpressions() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- getCustomOptions(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getCustomOptions(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Where an implementation supports OPTIONS in CREATE and ALTER operations
this method should return the Map<String, String>
representing the custom
options associated with the role, as supplied to CREATE or ALTER.
- getCustomOptions() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a Map<String, String>
representing custom options
It is the responsiblity of IRoleManager implementations which support
IRoleManager.Option.OPTION to handle type checking and conversion of these
values, if present
- getCustomPayload() - Method in class org.apache.cassandra.transport.Message
-
- getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- getData() - Method in class org.apache.cassandra.service.DataResolver
-
- getData() - Method in class org.apache.cassandra.service.DigestResolver
-
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
- getData() - Method in class org.apache.cassandra.service.ResponseResolver
-
- getDatacenter() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Gets the stored data center for the local node, or null if none have been set yet.
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.CloudstackSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used for this node
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String representing the datacenter this endpoint belongs to
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getDataCenters() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getDataChannel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getDataDirectoryForFile(Descriptor) - Method in class org.apache.cassandra.db.Directories
-
- getDataOffset() - Method in class org.apache.cassandra.index.sasi.Term
-
- getDays() - Method in class org.apache.cassandra.cql3.Duration
-
- getDecryptor(String, String, byte[]) - Method in class org.apache.cassandra.security.CipherFactory
-
- getDecryptor() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getDefaultGcBefore(ColumnFamilyStore, int) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getDefaultIndexName(String, String) - Static method in class org.apache.cassandra.schema.IndexMetadata
-
- getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- getDefinition() - Method in class org.apache.cassandra.db.view.View
-
- getDefinition() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getDelegate() - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
-
- getDelegates() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- getDelegates() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- getDelegates() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- getDelegates() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getDeleteSourceOnSuccess(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getDependentIndexes(ColumnDefinition) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA12
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA21
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA24
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA31
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA34
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA39
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA48
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA55
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA1
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA15
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA154
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA155
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA173
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA175
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA177
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA179
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA182
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA190
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA195
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA196
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA205
-
- getDescription() - Method in class org.apache.cassandra.cql3.Cql_Parser.DFA44
-
- getDescription() - Method in class org.apache.cassandra.cql3.CqlLexer.DFA1
-
- getDescriptor() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
-
- 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.CompactionStrategyManager
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
The directories we can write to
- getDirectoriesVersion() - Static method in class org.apache.cassandra.db.DisallowedDirectories
-
- getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
-
- getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getDisableSTCSInL0() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskBoundaries() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getDiskBoundaries(ColumnFamilyStore) - Method in class org.apache.cassandra.db.DiskBoundaryManager
-
- getDiskFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskIndex(SSTableReader) - Method in class org.apache.cassandra.db.DiskBoundaries
-
- getDiskOptimizationEstimatePercentile() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskOptimizationStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDouble(String, double) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getDownEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getDownEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getDrainProgress() - Method in class org.apache.cassandra.service.StorageService
-
- getDrainProgress() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the progress of a drain operation
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getDroppedColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
- getDroppedColumnDefinition(ByteBuffer, boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns a "fake" ColumnDefinition corresponding to the dropped column name
of null
if there is no such dropped column.
- getDroppedColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDroppedColumnsAsCQL(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
Build a CQL String representation of Dropped Columns in the given Column Family.
- getDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts for server lifetime
- getDroppedMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getDroppedMessages() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDurationUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicUpdateInterval() - Method in class org.apache.cassandra.service.StorageService
-
- getDynamicUpdateInterval() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getEffectiveIndexIntervalAfterIndex(int, int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Calculates the effective index interval after the entry at `index` in an IndexSummary.
- getEffectiveIndexIntervalAfterIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns the number of primary (on-disk) index entries between the index summary entry at `index` and the next
index summary entry (assuming there is one).
- getElement(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
-
Returns the element at the given index in a list.
- getElementCount(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- getElementCount(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- getElementCount(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- getElementCount(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- getElementIndex() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getElements() - Method in class org.apache.cassandra.cql3.Lists.Value
-
- getElements() - Method in class org.apache.cassandra.cql3.Term.MultiItemTerminal
-
- getElements() - Method in class org.apache.cassandra.cql3.Tuples.Value
-
- getElements() - Method in class org.apache.cassandra.cql3.UserTypes.Value
-
- getElementsType() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getElementsType() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getEnableMaterializedViews() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEnableSASIIndexes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEncodingStats() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getEncryptionContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEncryptionContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the encryption context used to encrypt the segments.
- getEncryptionContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getEncryptor(String, String) - Method in class org.apache.cassandra.security.CipherFactory
-
- getEncryptor() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getEndInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getEndpoint(Range<Token>) - Method in class org.apache.cassandra.client.RingCache
-
ListMultimap promises to return a List for get(K)
- getEndpoint(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getEndpointForHostId(UUID) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the end-point for a unique host ID
- getEndpointForHostId(UUID) - Method in class org.apache.cassandra.service.StorageService
-
- getEndpointInfo(InetAddress) - Static method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Get the raw information about an end point
- getEndpoints(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetEndpoints - Class in org.apache.cassandra.tools.nodetool
-
- GetEndpoints() - Constructor for class org.apache.cassandra.tools.nodetool.GetEndpoints
-
- getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getEndpointState(String) - Method in class org.apache.cassandra.gms.FailureDetector
-
- getEndpointState(String) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getEndpointStateForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointStates() - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointToHostId() - Method in class org.apache.cassandra.service.StorageService
-
- getEndpointToHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of endpoint to host ID
- getEndpointToHostIdMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpointToRangesMap() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getEndpointToTokenMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getEntities() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- getEntity() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedCompactionsByTasks(ColumnFamilyStore, List<List<SSTableReader>>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getEstimatedKeyCount() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns an estimate of the total number of keys in the SSTable.
- getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
Get a quick estimation on how many bytes have been written to disk
It should for the most part be exactly the same as getOnDiskFilePointer()
- getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getEstimatedPartitionSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- getEstimatedResultRows() - Method in interface org.apache.cassandra.index.Index
-
Return an estimate of the number of results this index is expected to return for any given
query that it can be used to answer.
- getEstimatedResultRows() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getEstimatedResultRows() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- getExactTypeIfKnown(String) - Method in interface org.apache.cassandra.cql3.selection.Selectable
-
The type of the Selectable
if it can be infered.
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
-
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.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
-
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Calculate expected file size of SSTable after compaction.
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.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
-
- getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getExpressions() - Method in class org.apache.cassandra.db.filter.RowFilter
-
- getExpressions() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- getFailureDetectorPhilValues() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getFailureReason() - Method in class org.apache.cassandra.net.MessageIn
-
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getfd(FileChannel) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
Get system file descriptor from FileDescriptor object.
- getField(Class<?>, String) - Static method in class org.apache.cassandra.utils.ReflectionUtils
-
- getFifteenMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getFileCacheRoundUp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getFileDescriptor() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getFilename() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- getFilePointer() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- getFilePointer() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getFiles(Path, BiFunction<File, Directories.FileType, Boolean>, Directories.OnTxnErr) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
Get the files in the folder specified, provided that the filter returns true.
- getFileStore(Path) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the FileStore
representing the file store where a file
is located.
- getFilter(long, int, boolean, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFilter(long, double, boolean, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFilteredCurrentToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- 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
-
- getFlushObserver(Descriptor, OperationType) - Method in interface org.apache.cassandra.index.Index
-
Get flush observer to observe partition/cell events generated by flushing SSTable (memtable flush or compaction).
- getFlushObserver(Descriptor, OperationType) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getForcedProtocolVersion() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- getForceNewPreparedStatementBehaviour() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFormat() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- getFreeSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the number of unallocated bytes on the specified partition.
- getFrozenList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getFrozenMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getFrozenSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getFrozenTextMap(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getFullyExpiredSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, int, boolean) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
Finds expired sstables
works something like this;
1.
- getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
- getFunctionName() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getFunctionName(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
-
Creates the name of the cast function use to cast to the specified type.
- getFunctionName(CQL3Type) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
-
Creates the name of the cast function use to cast to the specified type.
- getFunctions(FunctionName) - Method in class org.apache.cassandra.config.Schema
-
Get all function overloads with the specified name
- getFunctions() - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Return an Iterable over all of the functions (both native and user-defined) used by any component
of the statement
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getGCLogThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getGCWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getGossipMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for gossip message TCP Connections
- getGossipMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for gossip message TCP Connections
- getGossipMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for gossip message TCP Connections
- getGossProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getGroup() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the group to which the Metric
belongs.
- getHashBuckets(IFilter.FilterKey, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
-
- getHeader(CFMetaData) - Method in class org.apache.cassandra.streaming.StreamReader
-
- getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHeapSize() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.Token
-
- getHintedHandoffDisabledDCs() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintedHandoffDisabledDCs() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHintedHandoffDisabledDCs() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHintedHandoffThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getHintsCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getHintsDirectory() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getHintsFlushPeriodInMS() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHollowByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getHollowDirectByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getHollowDirectByteBuffer(ByteOrder) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getHost() - Method in interface org.apache.cassandra.net.BackPressureState
-
Returns the host this state refers to.
- getHostAddress(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostIdForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHostIdToEndpoint() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdToEndpoint() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of host ID to endpoint
- getHosts() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getId(String, String) - Method in class org.apache.cassandra.config.Schema
-
Lookup keyspace/ColumnFamily identifier
- getId() - Method in class org.apache.cassandra.cql3.statements.TableAttributes
-
- getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getId() - Method in class org.apache.cassandra.repair.RepairSession
-
- getId(ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
-
- getIdentifier(CFMetaData) - Method in class org.apache.cassandra.config.ColumnDefinition.Raw
-
- getIdx() - Method in class org.apache.cassandra.cql3.IndexName
-
- getIfExists(UUID) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Returns a ColumnFamilyStore by cfId if it exists, null otherwise
Differently from others, this method does not throw exception if the table does not exist.
- getIfExists(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Returns a ColumnFamilyStore by ksname and cfname if it exists, null otherwise
Differently from others, this method does not throw exception if the keyspace or table does not exist.
- getIgnoreHosts(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Get the hosts to ignore as a collection of strings
- getIndex(ColumnFamilyStore) - Method in class org.apache.cassandra.db.ReadCommand
-
- getIndex(IndexMetadata) - Method in interface org.apache.cassandra.index.IndexRegistry
-
- getIndex(ColumnDefinition) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
-
- getIndex(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- getIndex() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getIndex(IndexMetadata) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexBuildTask(ColumnFamilyStore, Set<Index>, Collection<SSTableReader>) - Method in class org.apache.cassandra.index.Index.CollatedViewIndexBuildingSupport
-
- getIndexBuildTask(ColumnFamilyStore, Set<Index>, Collection<SSTableReader>) - Method in interface org.apache.cassandra.index.Index.IndexBuildingSupport
-
- getIndexByName(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getIndexCfs() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getIndexChannel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexComparator() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getIndexedColumn() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
Extract the value to be inserted into the index from the components of the base data
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
-
- getIndexedValue(ByteBuffer, Clustering, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
-
- getIndexedValueType(ColumnDefinition) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
-
Returns the type of the the values in the index.
- getIndexes() - Method in class org.apache.cassandra.config.CFMetaData
-
- getIndexes() - Method in class org.apache.cassandra.index.sasi.conf.view.View
-
- getIndexes(Operation.OperationType, Collection<Expression>) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
Build a range iterator from the given list of expressions by applying given operation (OR/AND).
- getIndexesAsCQL(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
Build a CQL String representation of Indexes on columns in the given Column Family
- getIndexFile() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getIndexIntervals() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getIndexIntervals() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
Returns a map of SSTable filenames to their current effective index interval.
- getIndexMetadata() - Method in interface org.apache.cassandra.index.Index
-
Returns the IndexMetadata which configures and defines the index instance.
- getIndexMetadata() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getIndexMetadata() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getIndexName() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getIndexName(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
Returns the index name
- getIndexName(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
Returns the index name
- getIndexOperator(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TermSlice
-
Returns the index operator corresponding to the specified boundary.
- getIndexPath() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- getIndexRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- getIndexScanPosition(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Gets the position in the index file to start scanning to find the given key (at most indexInterval keys away,
modulo downsampling of the index summary).
- getIndexScanPositionFromBinarySearchResult(int, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSerializer(CFMetaData, Version, SerializationHeader) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getIndexSerializer(CFMetaData, Version, SerializationHeader) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getIndexSummaryCapacityInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummaryIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummaryKey(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the key for the index summary entry at `index`.
- getIndexSummaryOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummarySamplingLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the number of entries in the IndexSummary.
- 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.
- getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInitialDirectories() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getInitializationTask() - Method in interface org.apache.cassandra.index.Index
-
Return a task to perform any initialization work when a new index instance is created.
- getInitializationTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getInitializationTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getInitialTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCoreConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
may be null if unset
- getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeAuthProvider(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeKeepAlive(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReadConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReceiveBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReuseAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSendBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSolinger(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLCipherSuites(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLKeystorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLKeystorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLTruststorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLTruststorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeTcpNodelay(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputPageRowSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSplit() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSplitSizeInMb(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
cassandra.input.split.size will be used if the value is undefined or negative.
- getInputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInstance(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(AbstractType...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.FrozenType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(AbstractType<K>, AbstractType<V>, boolean) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.TupleType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.UserType
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
-
- getInstance(TypeSerializer<K>, TypeSerializer<V>, Comparator<ByteBuffer>) - Static method in class org.apache.cassandra.serializers.MapSerializer
-
- getInstance(TypeSerializer<T>, Comparator<ByteBuffer>) - Static method in class org.apache.cassandra.serializers.SetSerializer
-
- getInstanceForTesting() - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- getInt(String, Integer) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInt() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getInt(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getInt(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getInt(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- 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
-
- GetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
-
- getInterDCStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getInterDCStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getInterDCStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getInterned(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- getInterned(String, boolean) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- getInterned(AbstractType<?>, ByteBuffer, String) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- getInternodeAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInvalidateTask() - Method in interface org.apache.cassandra.index.Index
-
Return a task which invalidates the index, indicating it should no longer be considered usable.
- getInvalidateTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getInvalidateTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getInvalidMutations() - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
-
- getInValues() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- getInValues() - Method in class org.apache.cassandra.cql3.Relation
-
Returns the list of raw IN values for this relation, or null if this is not an IN relation.
- getInValues() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getInValues() - Method in class org.apache.cassandra.cql3.TokenRelation
-
- getIV() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getJmxMetric(MBeanServerConnection, String, String, String) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJmxThreadPools(MBeanServerConnection) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJobThreads() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently bootstrapping into the ring.
- getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getJsonColumnValue(int, ColumnIdentifier, Collection<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.QueryOptions
-
Returns the term corresponding to column columnName
in the JSON value of bind index bindIndex
.
- getJsonDateFormatter() - Static method in class org.apache.cassandra.serializers.TimestampSerializer
-
- getKey() - Method in class org.apache.cassandra.db.BufferDecoratedKey
-
- getKey() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getKey() - Method in class org.apache.cassandra.db.NativeDecoratedKey
-
- getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyPosition() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
-
- getKeyspace() - Method in class org.apache.cassandra.auth.FunctionResource
-
Get the name of the keyspace this resource relates to.
- getKeyspace() - Method in class org.apache.cassandra.cql3.UTName
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Get keyspace instance by name
- getKeyspaceName() - Method in class org.apache.cassandra.db.CounterMutation
-
- getKeyspaceName() - Method in interface org.apache.cassandra.db.IMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.db.Mutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- 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.
- getKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaces(Set<String>) - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKeysType() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getKeyType() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValidator() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- getKeyValidatorAsClusteringComparator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getKSChildDirectories(String) - Static method in class org.apache.cassandra.db.Directories
-
- getKSChildDirectories(String, Directories.DataDirectory[]) - Static method in class org.apache.cassandra.db.Directories
-
- getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace by its name
- getLargeMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for large message) TCP Connections
- getLargeMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for large message TCP Connections
- getLargeMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessagePendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for large message TCP Connections
- getLargestBucketOffset() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- getLastColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns the definition of the last column.
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getLastFlushOffset() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getLastIntervalAcquire() - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
-
- getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- getLastReturned() - Method in class org.apache.cassandra.db.DataRange.Paging
-
- getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getLatestVersion() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
caller should not modify leavingEndpoints
- getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently leaving the ring.
- getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLegacyUserdata(String, ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- getLevelCount() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelFanoutSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLevelFanoutSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getLevelFanoutSize() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getLevelFanoutSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLifetimeInMS() - Method in class org.apache.cassandra.net.MessageIn
-
Since how long (in milliseconds) the message has lived.
- getLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
Returns the limit specified by the user.
- getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLiveDataSize() - Method in class org.apache.cassandra.db.Memtable
-
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLiveNaturalEndpoints(Keyspace, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
This method attempts to return N endpoints that are responsible for storing the
specified key i.e for replication.
- getLiveNaturalEndpoints(Keyspace, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNaturalEndpoints(Keyspace, RingPosition, List<InetAddress>) - Method in class org.apache.cassandra.service.StorageService
-
This method attempts to return N endpoints that are responsible for storing the
specified key i.e for replication.
- getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of live nodes in the cluster, where "liveness" is
determined by the failure detector of the node being queried.
- getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLiveRingMembers() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveRingMembers(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveSortedEndpoints(Keyspace, ByteBuffer) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getLiveSortedEndpoints(Keyspace, RingPosition) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getLiveSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- getLoadMap() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value.
- getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLoadString() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value
- getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
Please use getBroadcastAddress instead.
- getLocalClockAndCount(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the clock and the count associated with the local counter id, or (0, 0) if no such shard is present.
- getLocalComparator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocale() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- 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
-
- getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getLocation(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getLocationForDisk(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories
-
Returns SSTable location which is inside given data directory.
- getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLogger(Logger, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
-
- getLoggingLevels() - Method in class org.apache.cassandra.service.StorageService
-
- getLoggingLevels() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the runtime logging levels
- getLoggingLevels() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetLoggingLevels - Class in org.apache.cassandra.tools.nodetool
-
- GetLoggingLevels() - Constructor for class org.apache.cassandra.tools.nodetool.GetLoggingLevels
-
- getLoggingLevels() - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
-
- getLoggingLevels() - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
-
- getLoggingLevels() - Method in class org.apache.cassandra.utils.logging.NoOpFallbackLoggingSupport
-
- getLoggingSupport() - Static method in class org.apache.cassandra.utils.logging.LoggingSupportFactory
-
- getLogin() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a boolean value of the login option
- getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getLong() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getLong(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getLong(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getLong(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getLongByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getMapKey() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getMappings() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- getMappings() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
-
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getMaxDataAge(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getMaxEntries() - Method in class org.apache.cassandra.auth.AuthCache
-
- getMaxEntries() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- getMaxHintsDeliveryThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintsFileSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- getMaximalTasks(int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- 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
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Returns maximum pool size of thread pool.
- 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
- getMaxIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the approximate number of entries the IndexSummary would contain if it were at full sampling.
- getMaxLocalDeletionTime() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMaxMutationSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxNativeProtocolVersion() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- getMaxNativeProtocolVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getMaxNativeProtocolVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the max version that this node will negotiate for native protocol connections
- getMaxNumberOfEntries() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns the number of entries this summary would have if it were at the full sampling level, which is equal
to the number of entries in the primary on-disk index divided by the min index interval.
- getMaxOutstandingVersionRequests() - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- getMaxProtocolVersion() - Method in class org.apache.cassandra.service.NativeTransportService
-
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMaxTokenLength() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- getMaxTTL() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMaxValueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxVersion() - Method in class org.apache.cassandra.transport.ConfiguredLimit
-
- getMaxVersion() - Method in interface org.apache.cassandra.transport.ProtocolVersionLimit
-
- 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
-
- 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
-
- getMeanColumns() - 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
-
- getMemoryPoolCapacityInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getMemoryPoolCapacityInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getMemoryPoolSizeInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
Returns the actual space consumed by index summaries for all sstables.
- getMemoryPoolSizeInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
Returns the current actual off-heap memory usage of the index summaries for all non-compacting sstables.
- getMemtableAllocationType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableCleanupThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableFor(OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
get the Memtable that the ordered writeOp should be directed to
- getMemtableHeapSpaceInMb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableOffheapSpaceInMb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableReservedSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
If not affected by MeteredFlusher (and handling flushing on its own), override to tell MF how much
space to reserve for this CF, i.e., how much space to subtract from `memtable_total_space_in_mb` when deciding
if other memtables should be flushed or not.
- getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- getMerkleTree(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get the MerkleTree responsible for the given token range.
- getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
-
- getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception message.
- getMessage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getMessages() - Method in class org.apache.cassandra.service.ResponseResolver
-
- getMessageType() - Method in class org.apache.cassandra.net.MessageIn
-
- getMessagingServiceProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getMetadata() - Method in class org.apache.cassandra.db.Keyspace
-
- getMetadataReloadTask(IndexMetadata) - Method in interface org.apache.cassandra.index.Index
-
Return a task to reload the internal metadata of an index.
- getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getMetadataSerializer() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- getMetricName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getMinFreeSpacePerDriveInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinimalKey(DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
as large as necessary.
- getMinimum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- getMinimum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the minimum number of sstables in queue before compaction kicks off
- getMinimumToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getMinLocalDeletionTime() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
-
- getMinLocalDeletionTime() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMinRepairedAt(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinTimestamp() - Method in class org.apache.cassandra.db.Memtable
-
Returns the minTS if one available, otherwise NO_MIN_TIMESTAMP.
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMinTokenLength() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- getMinTTL() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMinVersion(long, TimeUnit) - Method in class org.apache.cassandra.gms.Gossiper
-
- getMode() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getMode(ColumnDefinition, Optional<IndexMetadata>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- getMode(ColumnDefinition, Map<String, String>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- getMode() - Method in class org.apache.cassandra.index.sasi.sa.SA
-
- getMonths() - Method in class org.apache.cassandra.cql3.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
-
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently moving in the ring.
- getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- getMutations(BatchQueryOptions, boolean, long, long) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getName() - Method in class org.apache.cassandra.auth.CassandraPrincipal
-
Return the username for this CassPrincipal
.
- getName() - Method in class org.apache.cassandra.auth.DataResource
-
- getName() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getName() - Method in interface org.apache.cassandra.auth.IResource
-
- getName() - Method in class org.apache.cassandra.auth.JMXResource
-
- getName() - Method in class org.apache.cassandra.auth.RoleResource
-
- getName() - Method in class org.apache.cassandra.cql3.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.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
-
- getNameAsString() - Method in class org.apache.cassandra.db.marshal.UserType
-
- getNanoseconds() - Method in class org.apache.cassandra.cql3.Duration
-
- getNativeProtocolMaxVersionOverride() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeProtocolVersion() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
Return native version protocol of the cluster connection
- getNativeTransportMaxConcurrentConnections() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxConcurrentConnections() - Method in class org.apache.cassandra.service.StorageProxy
-
- getNativeTransportMaxConcurrentConnections() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getNativeTransportMaxConcurrentConnectionsPerIp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxConcurrentConnectionsPerIp() - Method in class org.apache.cassandra.service.StorageProxy
-
- getNativeTransportMaxConcurrentRequestsInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxConcurrentRequestsInBytesPerIp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxFrameSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportPortSSL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNaturalAndPendingEndpoints(String, Token) - Method in class org.apache.cassandra.service.StorageService
-
Returns the endpoints currently responsible for storing the token plus pending ones
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
get the (possibly cached) endpoints that should store the given Token.
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.LocalStrategy
-
We need to override this even if we override calculateNaturalEndpoints,
because the default implementation depends on token calculations but
LocalStrategy may be used before tokens are set up.
- getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
- getNaturalEndpoints(String, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNeighbors(String, Collection<Range<Token>>, Range<Token>, Collection<String>, Collection<String>) - Static method in class org.apache.cassandra.service.ActiveRepairService
-
Return all of the neighbors with whom we share the provided range.
- getNetworkInterface(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getNewEphemeralSnapshotMarkerFile(String) - Method in class org.apache.cassandra.db.Directories
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
Return the next background task
Returns a task for the compaction strategy that needs it the most (most estimated remaining tasks)
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
the only difference between background and maximal in LCS is that maximal is still allowed
(by explicit user request) even when compaction is disabled.
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getNextToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
Resumes scanning until the next regular expression is matched,
the end of input is encountered or an I/O-Error occurs.
- 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.config.Schema
-
- getNonLocalStrategyKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getNonLocalStrategyKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNonLocalStrategyKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getNonOverlappingBounds(Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
-
Retrieves non-overlapping bounds for the list of input bounds
Assume we have the following bounds
(brackets representing left/right bound):
[ ] [ ] [ ] [ ]
[ ] [ ]
This method will return the following bounds:
[ ] [ ]
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getNonSystemKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getNullable(String) - Method in class org.apache.cassandra.schema.Tables
-
Get the table with the specified name
- getNullable(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
-
Get the type with the specified name
- getNullable(String) - Method in class org.apache.cassandra.schema.Views
-
Get the view with the specified name
- getNumberOfTables() - Method in class org.apache.cassandra.config.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
-
- getNumPendingtasks() - Method in class org.apache.cassandra.utils.memory.MemtablePool
-
- getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Expert: gets the number of longs in the array that are in use
- getObjectName() - Method in class org.apache.cassandra.auth.AuthCache
-
- getObjectName() - Method in class org.apache.cassandra.auth.JMXResource
-
- getOffHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.Token
-
- getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Returns the current file pointer of the underlying on-disk file.
- getOneMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getOnlyElement(PartitionIterator, SinglePartitionReadCommand) - 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
-
- getOperationMode() - Method in class org.apache.cassandra.service.StorageService
-
- getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the operational mode (leaving, joining, normal, decommissioned, client)
- getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getOperations() - Method in class org.apache.cassandra.db.Memtable
-
- getOptions() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a map of all the options which have been set
- getOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getOrCreateNextSession(InetAddress, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getOrCreateSessionById(InetAddress, int, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getOrderingIndex(boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getOriginalIndexes(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Returns a list that can be used to translate current index summary indexes to their original index before
downsampling.
- 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() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtcBacklogExpirationInterval() - Method in class org.apache.cassandra.service.StorageProxy
-
- getOtcBacklogExpirationInterval() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getOtcCoalescingEnoughCoalescedMessages() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtcCoalescingStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtcCoalescingWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtherOptions() - Method in class org.apache.cassandra.schema.CompressionParams
-
- getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.Selector
-
Returns the selector output.
- getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.TermSelector
-
- getOutputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
The OutputCommitter for this format does not write any data to the DFS.
- getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocalDCOnly(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocation() - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- getOutputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getOutstandingSchemaVersions() - Method in class org.apache.cassandra.service.StorageService
-
- getOutstandingSchemaVersions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns a map of schema version -> list of endpoints reporting that version that we need schema updates for
- 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
-
given a list of tokens (representing the nodes in the cluster), returns
a mapping from "token -> %age of cluster owned by that token"
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getOwnershipByDc(NodeProbe, boolean, Map<String, String>, Map<InetAddress, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
-
- getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPager(PagingState, ProtocolVersion) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- getPager(PagingState, ProtocolVersion) - Method in interface org.apache.cassandra.db.ReadQuery
-
Returns a pager for the query.
- getPager(PagingState, ProtocolVersion) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- getPager(PagingState, ProtocolVersion) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.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.
- getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The paging state for this query, or null if not relevant.
- getPagingState() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- getParallelism() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getParent() - Method in class org.apache.cassandra.auth.DataResource
-
- getParent() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getParent() - Method in interface org.apache.cassandra.auth.IResource
-
Gets next resource in the hierarchy.
- getParent() - Method in class org.apache.cassandra.auth.JMXResource
-
- getParent() - Method in class org.apache.cassandra.auth.RoleResource
-
- getParentCfs(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getParentCfsName(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
- getParentColumnFamilyName() - Method in class org.apache.cassandra.config.CFMetaData
-
- getParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- getPartition(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
-
- getPartition(DecoratedKey, ReadExecutionController) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- getPartitionDeletion() - Method in interface org.apache.cassandra.db.DeletionInfo
-
- getPartitionDeletion() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitioner() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getPartitioner() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getPartitioner() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- getPartitioner() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Token
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getPartitioner() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitionerName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the cluster partitioner
- getPartitionerName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the cluster partitioner
- getPartitionKeyBindIndexes(CFMetaData) - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
Returns an array with the same length as the number of partition key columns for the table corresponding
to cfm.
- getPartitionKeyBounds(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the partition key bounds.
- getPartitionKeys(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the partition keys for which the data is requested.
- getPartitionSample(String, String, int, int, int, List<TableMetrics.Sampler>) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPartitionUpdate(UUID) - Method in class org.apache.cassandra.db.Mutation
-
- 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
-
- getPassword() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return the string value of the password option
- getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getPath() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- getPath() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getPeers() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingMemtables() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
a mutable map may be returned but caller should not modify it
- getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangesMM(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of pending ranges to endpoints that describe the ring topology
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getPermissions(IResource) - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getPermissions - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- getPermissions(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.PermissionsCache
-
- getPermissionsCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPermissionsUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPerPartitionLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
Returns the per partition limit specified by the user.
- getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPhiValues() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiValues() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPid() - Method in class org.apache.cassandra.utils.SigarLibrary
-
- getPointer(OnDiskIndex.PointerTerm, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerLevel
-
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getPosition() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
Returns the exact position in the uncompressed view of the file.
- getPosition() - Method in class org.apache.cassandra.index.sasi.sa.Term
-
- getPosition(PartitionPosition, SSTableReader.Operator, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- getPosition(PartitionPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Retrieves the position while updating the key cache and the stats.
- getPosition(PartitionPosition, SSTableReader.Operator, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Retrieves the position while updating the key cache and the stats.
- getPosition(PartitionPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getPosition(PartitionPosition, SSTableReader.Operator, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getPosition() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPositionInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Gets the position of the actual index summary entry in our Memory attribute, 'bytes'.
- getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
- getPostIndexQueryFilter(RowFilter) - Method in interface org.apache.cassandra.index.Index
-
Transform an initial RowFilter into the filter that will still need to applied
to a set of Rows after the index has performed it's initial scan.
- getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPreferredIP(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Get preferred IP for given endpoint if it is known.
- getPrefetchedRow(DecoratedKey, Clustering) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
Returns the prefetched row with the already performed modifications.
- getPreJoinTask(boolean) - Method in interface org.apache.cassandra.index.Index
-
Return a task to be executed before the node enters NORMAL state and finally joins the ring.
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- getPreparedForThrift(Integer) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPreparedStatements() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPreparedStatementsCacheSizeMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPreviousReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getPrimaryRangeForEndpointWithinDC(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
- getPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPrimaryRangesFor(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPrimaryRangesForEndpoint(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Get the "primary ranges" for the specified keyspace and endpoint.
- getPrimaryRangesWithinDC(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPrimaryRole() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- getProcessID() - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- getProcessor(CassandraServer) - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getProgressCount() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getProgressPercentage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getProtectedConstructor(Class<T>, Class<?>...) - Static method in class org.apache.cassandra.utils.Hex
-
Used to get access to protected/private constructor of the specified class
- getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Used to get access to protected/private field of the specified class
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The protocol version for the query.
- getProtocolVersion() - Method in enum org.apache.cassandra.transport.DataType
-
- getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- getPurgeEvaluator() - Method in class org.apache.cassandra.db.partitions.PurgeFunction
-
- getQuery(QueryOptions, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getQuery(QueryOptions, int, int, int, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getQueryOrIdList() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getQueryState() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getRack() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Gets the stored rack for the local node, or null if none have been set yet.
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.CloudstackSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used for this node
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String repesenting the rack this endpoint belongs to
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getRack() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRandomInt(int) - Method in class org.apache.cassandra.batchlog.BatchlogManager.EndpointFilter
-
- getRandomTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Similar to getTimeUUIDFromMicros
, but randomize (using SecureRandom) the clock and sequence.
- getRandomToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken(Random) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
-
- getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getRange(int, int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataBlock
-
- getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getRanges() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getRanges() - Method in class org.apache.cassandra.repair.RepairSession
-
- getRangeSlice(PartitionRangeReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToAddressMapInLocalDC(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding listen addresses.
- getRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to end points that describe the ring topology
of a Cassandra cluster.
- getRangeToRpcaddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding RPC addresses for a given keyspace.
- getRangeToRpcaddressMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to rpc addresses that describe the ring topology
of a Cassandra cluster.
- getRateLimiter() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Gets compaction rate limiter.
- getRateLimiter(InetAddress) - 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
-
- 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
-
- getRawOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getRawTermForColumn(ColumnDefinition, 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.AbstractBufferClusteringPrefix
-
- 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
-
- getRawVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
Returns the messaging-version exactly as announced by the given endpoint.
- getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getReaderFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getReadExecutor(SinglePartitionReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
-
- getReadMeter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getReadQuery() - Method in class org.apache.cassandra.db.view.View
-
Returns the ReadQuery used to filter this view.
- getReadRepairAttempted() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairAttempted() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairAttempted() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBackground() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBlocking() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getRealVersion() - Method in class org.apache.cassandra.config.Schema
-
The 3.11 schema version, always includes the cdc
column.
- getReceivedCount() - Method in class org.apache.cassandra.service.ReadCallback
-
- getReceivingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getReceivingStream(UUID) - Method in class org.apache.cassandra.streaming.StreamManager
-
- getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getRecentBloomFilterTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getReclaiming() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
-
- getReclaiming() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Get the RecordWriter
for the given task.
- getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegularColumns() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getRegularOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getRelativePath(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Convert absolute path into a path relative to the base path
- getReleaseVersion(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Get release version for given endpoint.
- getReleaseVersion() - Method in class org.apache.cassandra.gms.EndpointState
-
- getReleaseVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the Cassandra version.
- getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReleaseVersionMajor() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getRemoteAddress() - Method in class org.apache.cassandra.service.ClientState
-
- getRemovalStatus() - Method in class org.apache.cassandra.service.StorageService
-
Get the status of a token removal.
- getRemovalStatus() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the status of a token removal.
- getRemovalStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRepairedAt() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- getRepairSessionMaxTreeDepth() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRepairSessionMaxTreeDepth() - Method in class org.apache.cassandra.service.StorageService
-
- getRepairSessionMaxTreeDepth() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplacementNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplacingNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getReplicas() - Method in class org.apache.cassandra.dht.tokenallocator.NoReplicationTokenAllocator
-
- getReplicas() - Method in class org.apache.cassandra.dht.tokenallocator.TokenAllocatorBase
-
- getReplicatedKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the RF based on strategy_options.
- getReplicationFactor() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- getReplicationOptions() - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
-
- getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getResizeIntervalInMinutes() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getResizeIntervalInMinutes() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- getRestoreCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestoreCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Command to execute to make an archived commitlog live again
- getRestoreDirectories() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestoreDirectories() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Directory to scan the recovery files in
- getRestorePointInTime() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestorePointInTime() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Restore mutations created up to and including this timestamp in GMT
Format: yyyy:MM:dd HH:mm:ss (2012:04:31 20:43:12)
Recovery will continue through the segment when the first client-supplied
timestamp greater than this time is encountered, but only mutations less than
or equal to this timestamp will be applied.
- getRestorePrecision() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestorePrecision() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
get precision of the timestamp used in the restore (MILLISECONDS, MICROSECONDS, ...)
to determine if passed the restore point in time.
- getRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- getRestrictions(ColumnDefinition) - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
-
Returns the restrictions applied to the specified column.
- getRestrictions(ColumnDefinition) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getRestrictions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getRestrictions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getResultMetadata(boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getResultSetIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
-
Returns the index of the specified column within the resultset
- getReturnType() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Returns the type of the values returned by the selector instances created by this factory.
- getReversableType(ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.cql3.statements.CFProperties
-
- getRingVersion() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getRoleManager() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRoleName() - Method in class org.apache.cassandra.auth.RoleResource
-
- getRoles() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Get the roles that have been granted to the user via the IRoleManager
- getRoles(RoleResource, boolean) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getRoles(RoleResource, boolean) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of a LIST ROLES query.
- getRoles(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
-
Get all roles granted to the supplied Role, including both directly granted
and inherited roles.
- getRoles(RoleResource) - Method in class org.apache.cassandra.auth.RolesCache
-
- getRolesCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRolesUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRolesValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRow() - Method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
Generates the row currently grouped by this grouper and reset it for the following row.
- getRow(Clustering) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- getRow(Clustering) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
- getRow(Clustering) - Method in interface org.apache.cassandra.db.partitions.Partition
-
Returns the row corresponding to the provided clustering, or null if there is not such row.
- getRowCacheClassName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowFilter(SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- getRowFilter(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getRowMergeListener(DecoratedKey, List<UnfilteredRowIterator>) - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
-
- getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcaddress(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Return the rpc address associated with an endpoint as a string.
- getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcListenBacklog() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcServerType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getSamplingLevel() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getSamplingPattern(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Gets a list L of starting indices for downsampling rounds: the first round should start with the offset
given by L[0], the second by the offset in L[1], etc.
- getSaslNegotiator(QueryState) - Method in class org.apache.cassandra.transport.ServerConnection
-
- getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the saved caches dir
- getSavedTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getScanner(ColumnFilter, DataRange, RateLimiter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Direct I/O SSTableScanner over an iterator of bounds.
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Direct I/O SSTableScanner over the full sstable.
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanner(SSTableReader, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner(SSTableReader, ColumnFilter, DataRange, RateLimiter, boolean, SSTableReadsListener) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner(SSTableReader, Collection<Range<Token>>, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner(SSTableReader, Iterator<AbstractBounds<PartitionPosition>>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
I/O SSTableScanner
- getScanner(ColumnFilter, DataRange, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over the entirety of the sstable..
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over an iterator of bounds.
- getScanner(ColumnFilter, DataRange, RateLimiter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getScanners(Collection<SSTableReader>, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Returns a list of KeyScanners given sstables and a range on which to scan.
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getScanners(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
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getScanners(Collection<SSTableReader>, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getSchedulingValue() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getSchemaVersion() - Method in class org.apache.cassandra.gms.EndpointState
-
- getSchemaVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getSchemaVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getSchemaVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the current Schema version.
- getSchemaVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
-
- getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Returns each live node's schema version
- getScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the scope of the Metric
.
- getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getSecretKey(String) - Method in class org.apache.cassandra.security.JKSKeyProvider
-
- getSecretKey(String) - Method in interface org.apache.cassandra.security.KeyProvider
-
- getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
-
- getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
-
- getSeekPosition() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
Return a seekable representation of the current position.
- getSeekPosition() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
- getSeekPosition() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
-
- getSelection() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getSelectStatement() - Method in class org.apache.cassandra.db.view.View
-
Returns the SelectStatement used to populate and filter this view.
- getSendingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Serial consistency for conditional updates.
- getSerializedCachePath(CacheService.CacheType, String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSerializedValue(ByteBuffer, ByteBuffer, AbstractType) - Method in class org.apache.cassandra.serializers.MapSerializer
-
Given a serialized map, gets the value associated with a given key.
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ByteType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DurationType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LongType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ShortType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UserType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- getServerEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
- getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
-
- getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
-
- getSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getSeverity() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSeverity() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getShort(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getShort() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getShort(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- getShort(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getShortByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- getSimple(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getSimple(int) - Method in class org.apache.cassandra.db.Columns
-
Returns the ith simple column of this object.
- getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getSlices(CFMetaData) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
- getSlices(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- getSlices(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- getSlowQueryTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSlowQueryTimeout() - Method in class org.apache.cassandra.net.MessageIn
-
- getSmallMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for small message TCP Connections
- getSmallMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for small message TCP Connections
- getSmallMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for small message TCP Connections
- getSnapshot() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Returns a snapshot of the decaying values in this reservoir.
- getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDetails() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDetails() - Method in class org.apache.cassandra.db.Directories
-
- getSnapshotDetails() - Method in class org.apache.cassandra.service.StorageService
-
- getSnapshotDetails() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the details of all the snapshot
- getSnapshotDetails() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
-
- getSnapshotDirectory(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Returns directory to write snapshot.
- getSnapshotManifestFile(String) - Method in class org.apache.cassandra.db.Directories
-
- 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
-
- getSnapshotSchemaFile(String) - Method in class org.apache.cassandra.db.Directories
-
- getSnapshotSSTableReader(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnitchName() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getSnitchName() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the snitch name of the cluster
- getSocket(EncryptionOptions, InetAddress, int, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect
- getSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect, using any local address
- getSocket(EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
-
Just create a socket
- getSocket() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Returns a reference to the underlying socket.
- getSocketThreads() - Method in class org.apache.cassandra.net.MessagingService
-
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the Collection of node addresses by proximity to the given address
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a new List sorted by proximity to the given endpoint
- getSourceFrame() - Method in class org.apache.cassandra.transport.Message
-
- 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
-
- getSpecifications() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- getSplits(JobConf, int) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- getSplits(String, String, Range<Token>, int) - Method in class org.apache.cassandra.service.StorageService
-
- getSplitValues() - Method in class org.apache.cassandra.cql3.Tuples.InValue
-
- getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSLOptions(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSTable() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- getSstableCompressor() - Method in class org.apache.cassandra.schema.CompressionParams
-
Returns the SSTable compressor.
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTableCountPerLevel() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getSSTablePath(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablePath(File, SSTableFormat.Type) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablePreempiveOpenIntervalInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Returns a RestorableMeter tracking the average read rate of a particular SSTable, restoring the last-seen rate
from values in system.sstable_activity if present.
- getSSTables(SSTableSet) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTables() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getSSTables(String, String, String, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetSSTables - Class in org.apache.cassandra.tools.nodetool
-
- GetSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.GetSSTables
-
- getSSTableSectionsForRanges(Collection<Range<Token>>, Collection<ColumnFamilyStore>, long, boolean) - Static method in class org.apache.cassandra.streaming.StreamSession
-
- getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesForKey(String, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesForKey(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSSTablesForKey(String, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSStablesPerLevelSnapshot() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
-
Retrieve a stage from the StageManager
- getStage() - Method in class org.apache.cassandra.net.MessageOut
-
- getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
- getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getStatement(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getStatement(Logger, String, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, String) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, long, TimeUnit) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getStaticColumns() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getStaticOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getStaticType() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatementColumn
-
- getStatus() - Method in class org.apache.cassandra.gms.EndpointState
-
- getStatus(ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getStemmer(Locale) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.StemmerFactory
-
- getStopWordsForLanguage(Locale) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFactory
-
- getStorageMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStorageService() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStoredPreparedStatement(String, String, boolean) - 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
-
- getStreamId() - Method in class org.apache.cassandra.transport.Message
-
- getStreamId() - Method in exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
-
- getStreamingKeepAlivePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStreamingSocketTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getStreamingSocketTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetStreamThroughput
-
- getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getString(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a string representation of the bytes used for various identifier (NOT just for log messages)
- getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getStringTypeName() - Method in class org.apache.cassandra.cql3.UTName
-
- getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
-
- getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
-
- getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.Term
-
- getSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.StrategySummary
-
- getSummary() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getSuperBlock(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
-
- getSuperCfKeyColumn(CFMetaData, List<ColumnDefinition>, CompactTables.DefaultNames) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
Find a SuperColumn key column if it's available (for example, when it was renamed) or create one with a default name.
- getSuperCfSschemaRepresentation(ColumnDefinition) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
SuperColumn key is stored in
CFMetaData.columnMetadata
as a clustering column (to make sure we can make
a distinction between the SuperColumn key and SuperColumn value columns, especially when they have the same type
and were renamed), but exposed as
CFMetaData.superCfKeyColumn
as a regular column to be compatible with
the storage engine.
- getSuperCfValueColumn(CFMetaData, PartitionColumns, ColumnDefinition, CompactTables.DefaultNames) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
Find a SuperColumn value column if it's available (for example, when it was renamed) or create one with a default name.
- getSuperColumnRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- getSuperuser() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a boolean value of the superuser option
- getSyncPoint() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
returns the Group we are waiting on - any Group with .compareTo(getSyncPoint()) <= 0
must complete before await() returns
- getTable() - Method in class org.apache.cassandra.auth.DataResource
-
- getTableForAlias(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTableInsertStatement(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTableMetadata(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Validate that keyspace
is an existing keyspace and cfName
one of its existing column family.
- getTableMetadata(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- getTableName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTableName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getTableOrViewNullable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- getTablesAndViews(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace inner ColumnFamilies
- getTableSchema(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTablesWithSizeEstimates() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTargetIndex() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
-
- getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getTaskAttemptID(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
returns TaskAttemptContext.getTaskAttemptID().
- getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTemporaryFiles() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
Return any temporary files found in the directory
- getTemporaryWriteableDirectoryAsFile(long) - Method in class org.apache.cassandra.db.Directories
-
Returns a temporary subdirectory on allowed data directory
that _currently_ has writeSize
bytes as usable space.
- getTerm(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- getTerm() - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
-
- getTerm() - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
-
- getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.IntegralSA
-
- getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SA
-
- getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SuffixSA
-
- getTerm() - Method in class org.apache.cassandra.index.sasi.sa.Term
-
- getTerm() - Method in class org.apache.cassandra.index.sasi.Term
-
- getTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- getTermPosition(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- getText() - Method in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
-
- getText() - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- getText() - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- getText() - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- getText() - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- getText() - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- getText() - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- getText() - Method in class org.apache.cassandra.cql3.Term.Raw
-
- getText() - Method in class org.apache.cassandra.cql3.Tuples.Literal
-
- getText() - Method in class org.apache.cassandra.cql3.TypeCast
-
- getText() - Method in class org.apache.cassandra.cql3.UserTypes.Literal
-
- getText() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
- getText() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
-
- getTextMap(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- 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
-
- getThreadPools() - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve threadpool paths and names for threadpools with metrics.
- getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getThriftFramedTransportSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getThriftPreparedStatementsCacheSizeMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTimeout() - Method in class org.apache.cassandra.db.CounterMutation
-
- getTimeout() - Method in interface org.apache.cassandra.db.IMutation
-
- getTimeout() - Method in class org.apache.cassandra.db.Mutation
-
- getTimeout() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- getTimeout() - Method in class org.apache.cassandra.db.ReadCommand
-
The configured timeout for this command.
- getTimeout() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageIn
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageOut
-
- getTimeout() - Method in enum org.apache.cassandra.net.MessagingService.Verb
-
- getTimeout(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetTimeout - Class in org.apache.cassandra.tools.nodetool
-
- GetTimeout() - Constructor for class org.apache.cassandra.tools.nodetool.GetTimeout
-
- getTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts per host
- getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimestamp(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getTimestamp() - Method in class org.apache.cassandra.service.ClientState
-
This clock guarantees that updates for the same ClientState will be ordered
in the sequence seen, even if multiple updates happen in the same millisecond.
- getTimestamp() - Method in class org.apache.cassandra.service.QueryState
-
This clock guarantees that updates for the same QueryState will be ordered
in the sequence seen, even if multiple updates happen in the same millisecond.
- getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Keyspace
-
- getTimestampedSnapshotNameWithPrefix(String, String) - Static method in class org.apache.cassandra.db.Keyspace
-
- getTimestampForPaxos(long) - Method in class org.apache.cassandra.service.ClientState
-
Returns a timestamp suitable for paxos given the timestamp of the last known commit (or in progress update).
- getTimeToLive(QueryOptions, CFMetaData) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimeToLive(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID).
- getTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID) with the timestamp of @param when, in milliseconds.
- getTimeUUID(long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- getTimeUUID(long, long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a 16 byte representation of a type 1 UUID (a time-based UUID),
based on the current system time.
- getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a 100-nanoseconds precision timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a version 1 UUID using the provided timestamp and the local clock and sequence.
- getToken() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
Generate the token of a key.
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToken() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getToken() - Method in class org.apache.cassandra.dht.Token
-
- getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthChallenge
-
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthSuccess
-
- 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
-
- getTokenNames() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- getTokenNames() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getTokens() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
-
- getTokens() - Method in class org.apache.cassandra.index.sasi.sa.Term
-
- getTokens(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getTokens(String) - Method in class org.apache.cassandra.service.StorageService
-
- getTokens() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for this node.
- getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for a specified node.
- getTokens() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of tokens to endpoints, including the bootstrapping
ones.
- getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenTreeBuilder() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenValue() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getTokenValue() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getTokenValue() - Method in class org.apache.cassandra.dht.Token
-
- getTombstoneFailureThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTombstoneFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getTombstoneFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for abandoning queries with many tombstones
- getTombstoneWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTombstoneWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getTombstoneWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for warning of queries with many tombstones
- getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTotal() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getTotalBatchesReplayed() - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- getTotalBatchesReplayed() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
-
- getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalBytesScanned() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- getTotalColumnsSet() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- getTotalCompressedSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalRows() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTotalSinceLastCheck() - Method in class org.apache.cassandra.service.GCInspector
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalSizeForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- getTotalSizeReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSourceCQLRows() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- getTotalSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the size of the specified partition.
- getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Total number of timeouts happened on this node
- getTotalUncompressedBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTraceHeaders() - Method in class org.apache.cassandra.tracing.Tracing
-
- getTraceProbability() - Method in class org.apache.cassandra.service.StorageService
-
- getTraceProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the configured tracing probability.
- getTraceProbability() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetTraceProbability - Class in org.apache.cassandra.tools.nodetool
-
- GetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.GetTraceProbability
-
- getTraceType() - Method in class org.apache.cassandra.tracing.Tracing
-
- getTracetypeQueryTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTracetypeRepairTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
-
- getTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Package protected for access from the CompactionManager.
- getTracker() - Method in class org.apache.cassandra.transport.Connection
-
- getTransferredRanges(String, String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTransparentDataEncryptionOptions() - Method in class org.apache.cassandra.security.EncryptionContext
-
- getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTriggers() - Method in class org.apache.cassandra.config.CFMetaData
-
- getTrueAllocatedSizeIn(File) - Method in class org.apache.cassandra.db.Directories
-
- getTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getTruncatedAt(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncatedPosition(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncateRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getTruncateTask(long) - Method in interface org.apache.cassandra.index.Index
-
Return a task to truncate the index with the specified truncation timestamp.
- getTruncateTask(long) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- getTruncateTask(long) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- getTTL() - Method in class org.apache.cassandra.tracing.Tracing
-
- getTTL() - Method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
- getTupleType(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.Tuples
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- getType() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Returns the Selector
output type.
- getType() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- getType() - Method in class org.apache.cassandra.cql3.selection.TermSelector
-
- getType() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- getType(ColumnDefinition) - Method in class org.apache.cassandra.db.SerializationHeader
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- getType() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the type to which the Metric
belongs.
- getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.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 interface org.apache.cassandra.serializers.TypeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- getType() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUDType(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Returns the User Defined type, used in this SSTable Writer, that can
be used to create UDTValue instances.
- getUncompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUnfilteredRowIterator(ColumnFilter, Partition) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
Given a partition, returns a row iterator for the rows of this partition that are selected by this filter.
- getUnfilteredRowIterator(ColumnFilter, Partition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- getUnfilteredRowIterator(ColumnFilter, Partition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- 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
-
- getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of unreachable nodes in the cluster, as determined
by this node's failure detector.
- getUnreachableNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getUnreachableTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getUnreadableDirectories() - Method in class org.apache.cassandra.db.DisallowedDirectories
-
- getUnreadableDirectories() - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
-
- 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
-
- getUnwritableDirectories() - Method in class org.apache.cassandra.db.DisallowedDirectories
-
- getUnwritableDirectories() - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
-
- getUpdateCount(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the count associated with the update counter id, or 0 if no such shard is present.
- getUpdateInterval() - Method in class org.apache.cassandra.auth.AuthCache
-
- getUpdateInterval() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getUpdateTimestamp() - Method in class org.apache.cassandra.gms.EndpointState
-
- getUpEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getUpEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getUsableSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the number of available bytes on the specified partition.
- getUser() - Method in class org.apache.cassandra.service.ClientState
-
- getUserDefinedFunctionFailTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getUserDefinedFunctionWarnTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- getUserDefinedTasks(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
Return a list of compaction tasks corresponding to the sstables requested.
- getUserDefinedTasks(Collection<SSTableReader>, int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- getUserFunctionTimeoutPolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getUserKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getUserTypeName() - Method in class org.apache.cassandra.cql3.UTName
-
- getUserTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUserTypesAsCQL(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
Build a CQL String representation of User Types used in the given Column Family.
- getUUID(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
-
creates a type 1 uuid from raw bytes.
- getValidator() - Method in 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
-
- 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.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(CFMetaData, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- getValue() - Method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
-
- getValue() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxGaugeMBean
-
- getValueOf(ColumnDefinition, Row, int) - Static method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestriction
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestrictionWithMarkers
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestrictionWithValues
-
- getValuesType() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getVerbHandler(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
This method returns the verb handler associated with the registered
verb.
- getVerifyInfo() - Method in class org.apache.cassandra.db.compaction.Verifier
-
- getVersion() - Method in class org.apache.cassandra.config.Schema
-
The schema version to announce.
- getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getVersion(String) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- getVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
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
.
- getVersion(String) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
- GetVersion - Class in org.apache.cassandra.tools
-
- GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
-
- getVersion() - Method in class org.apache.cassandra.transport.Connection
-
- getVersionInfoUnsafe(UUID) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- getView(String, String) - Method in class org.apache.cassandra.config.Schema
-
- 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
-
- 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
-
- getViewBuildStatuses(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getViewColumn(ColumnDefinition) - Method in class org.apache.cassandra.db.view.View
-
The view column corresponding to the provided base column.
- getViewNaturalEndpoint(String, Token, Token) - Static method in class org.apache.cassandra.db.view.ViewUtils
-
Calculate the natural endpoint for the view.
- getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Return how many threads are waiting
- getWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- getWarnings() - Method in class org.apache.cassandra.transport.Message.Response
-
- getWindowBoundsInMillis(TimeUnit, int, long) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
Find the lowest and highest timestamps in a given timestamp/unit pair
Returns milliseconds, caller should adjust accordingly
- getWindowsTimerInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWorkMap(Multimap<Range<Token>, InetAddress>, String, IFailureDetector, boolean) - Static method in class org.apache.cassandra.dht.RangeStreamer
-
- 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
-
- getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- 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, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType, long) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getWriterFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- gLexer - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- global() - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
-
- globalCount() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
A convenience method for reporting:
- globalPartitioner() - Static method in class org.apache.cassandra.net.MessagingService
-
- globalPercentRepaired - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
- globalRangeLatency - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
- globalReadLatency - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
- globalWriteLatency - Static variable in class org.apache.cassandra.metrics.TableMetrics
-
- goodPartitions - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
-
- GoogleCloudSnitch - Class in org.apache.cassandra.locator
-
A snitch that assumes an GCE region is a DC and an GCE availability_zone
is a rack.
- GoogleCloudSnitch() - Constructor for class org.apache.cassandra.locator.GoogleCloudSnitch
-
- GossipDigest - Class in org.apache.cassandra.gms
-
Contains information about a specified list of Endpoints and the largest version
of the state they have generated as known by the local endpoint.
- GossipDigestAck - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestSynMessage by an
endpoint.
- GossipDigestAck2 - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestAckMessage.
- GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- GossipDigestSyn - Class in org.apache.cassandra.gms
-
This is the first message that gets sent out as a start of the Gossip protocol in a
round.
- GossipDigestSyn(String, String, List<GossipDigest>) - Constructor for class org.apache.cassandra.gms.GossipDigestSyn
-
- GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- Gossiper - Class in org.apache.cassandra.gms
-
This module is responsible for Gossiping information for the local endpoint.
- Gossiper.Props - Class in org.apache.cassandra.gms
-
- GossiperMBean - Interface in org.apache.cassandra.gms
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
called after Gossiper instance exists immediately before it starts gossiping
- gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- GossipInfo - Class in org.apache.cassandra.tools.nodetool
-
- GossipInfo() - Constructor for class org.apache.cassandra.tools.nodetool.GossipInfo
-
- GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
-
- GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossipMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for gossip message TCP Connections
- gossipMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for gossip message TCP Connections
- gossipMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for gossip message TCP Connections
- gossipMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
-
- GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
-
- gossProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- gParent - Variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- gParent - Variable in class org.apache.cassandra.cql3.Cql_Parser
-
- gParser - Variable in class org.apache.cassandra.cql3.CqlParser
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Grants a set of permissions on a resource to a role.
- grantee - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- grantee - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- grantee - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- grantPermissionsStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- grantPermissionsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- GrantPermissionsStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantPermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
Schema alteration may result in a new database object (keyspace, table, role, function) being created capable of
having permissions GRANTed on it.
- grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of GRANT ROLE query.
- grantRoleStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- grantRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- GrantRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantRoleStatement
-
- Group(List<SinglePartitionReadCommand>, DataLimits) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- GROUP_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.GroupMaker
-
GroupMaker
that groups all the rows together.
- GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
-
- groupByClause(List<ColumnDefinition.Raw>) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- groupByClause(List<ColumnDefinition.Raw>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- groupByLimits(int, int, int, AggregationSpecification) - Static method in class org.apache.cassandra.db.filter.DataLimits
-
- GroupByPartitionIterator(int, ConsistencyLevel, ClientState, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
-
- GroupByPartitionIterator(int, ReadExecutionController, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
-
- 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
-
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Method for grouping similar SSTables together, This will be used by
anti-compaction to determine which SSTables should be anitcompacted
as a group.
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
DTCS should not group sstables for anticompaction - this can mix new and old data
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
Leveled compaction strategy has guarantees on the data contained within each level so we
have to make sure we only create groups of SSTables with members from the same level.
- 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 - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
-
- guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- guidAsBytes(Random, String, long) - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- GuidGenerator - Class in org.apache.cassandra.utils
-
- GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
-
- guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- I - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- I - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- I - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- I - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IAsyncCallback<T> - Interface in org.apache.cassandra.net
-
implementors of IAsyncCallback need to make sure that any public methods
are threadsafe with respect to response() being called from the message
service.
- IAsyncCallbackWithFailure<T> - Interface in org.apache.cassandra.net
-
- IAuthenticator - Interface in org.apache.cassandra.auth
-
- IAuthenticator.SaslNegotiator - Interface in org.apache.cassandra.auth
-
Performs the actual SASL negotiation for a single authentication attempt.
- IAuthorizer - Interface in org.apache.cassandra.auth
-
Primary Cassandra authorization interface.
- IBitSet - Interface in org.apache.cassandra.utils.obs
-
- ICache<K,V> - Interface in org.apache.cassandra.cache
-
This is similar to the Map interface, but requires maintaining a given capacity
and does not require put or remove to return values, which lets SerializingCache
be more efficient by avoiding deserialize except on get.
- ICompressor - Interface in org.apache.cassandra.io.compress
-
- 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 class org.apache.cassandra.schema.IndexMetadata
-
- id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- id - Variable in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
-
- IDENT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- IDENT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- ident() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- ident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- IdentityCollection(Set<RefCounted.Tidy>) - Constructor for class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
-
- IDEOGRAPHIC_TYPE - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
- idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
-
- idxName(IndexName) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- idxName(IndexName) - Method in class org.apache.cassandra.cql3.CqlParser
-
- IEndpointLifecycleSubscriber - Interface in org.apache.cassandra.service
-
Interface on which interested parties can be notified of high level endpoint
state changes.
- IEndpointSnitch - Interface in org.apache.cassandra.locator
-
This interface helps determine location of node in the data center relative to another node.
- IEndpointStateChangeSubscriber - Interface in org.apache.cassandra.gms
-
This is called by an instance of the IEndpointStateChangePublisher to notify
interested parties about changes in the the state associated with any endpoint.
- IF_EXISTS_CONDITION - Static variable in interface org.apache.cassandra.cql3.Conditions
-
IF EXISTS condition
- IF_NOT_EXISTS_CONDITION - Static variable in interface org.apache.cassandra.cql3.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.
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropViewStatement
-
- ifile - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- ifile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- ifile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- IFilter - Interface in org.apache.cassandra.utils
-
- IFilter.FilterKey - Interface in org.apache.cassandra.utils
-
- IGNORE_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- IGNORE_NODES_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- IGNORE_UNREPLICATED_KS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- IGNORED_ENDPOINTS_PROP - Static variable in class org.apache.cassandra.service.MigrationCoordinator
-
- IGNORED_VERSIONS_PROP - Static variable in class org.apache.cassandra.service.MigrationCoordinator
-
- ignoreOverlaps() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
Is overlapped sstables ignored
Control whether or not we are taking into account overlapping sstables when looking for fully expired sstables.
- ignoreOverlaps() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionController
-
- ignoreOverlaps - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- ignores - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- ignores - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- ignoreStopTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
- ignoreUnreplicatedKeyspaces() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- IInternodeAuthenticator - Interface in org.apache.cassandra.auth
-
- ILatencySubscriber - Interface in org.apache.cassandra.locator
-
- ILifecycleTransaction - Interface in org.apache.cassandra.db.lifecycle
-
- IMeasurableMemory - Interface in org.apache.cassandra.cache
-
- IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
-
- IMessageSink - Interface in org.apache.cassandra.net
-
- IMetadataComponentSerializer<T extends MetadataComponent> - Interface in org.apache.cassandra.io.sstable.metadata
-
Metadata component serializer
- IMetadataSerializer - Interface in org.apache.cassandra.io.sstable.metadata
-
Interface for SSTable metadata serializer
- ImmutableBTreePartition - Class in org.apache.cassandra.db.partitions
-
- ImmutableBTreePartition(CFMetaData, DecoratedKey, PartitionColumns, Row, Object[], DeletionInfo, EncodingStats) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
- ImmutableBTreePartition(CFMetaData, DecoratedKey, AbstractBTreePartition.Holder) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
-
- 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
-
- 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.config.ViewDefinition
-
- includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- includeRow(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- includes(ColumnIdentifier) - Method in class org.apache.cassandra.config.ViewDefinition
-
- includes(PartitionColumns) - Method in class org.apache.cassandra.db.PartitionColumns
-
- includes(ColumnDefinition) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- includes(Cell, LivenessInfo) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- includes(CellPath) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- includes(ClusteringComparator, ClusteringPrefix) - Method in class org.apache.cassandra.db.Slice
-
Returns whether a given clustering or bound is included in this slice.
- includes(Clustering) - Method in interface org.apache.cassandra.db.Slices.InOrderTester
-
- IncludingExcludingBounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
-
AbstractBounds containing only its left endpoint: [left, right).
- IncludingExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.IncludingExcludingBounds
-
- inclusive - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
-
- inclusive - Variable in class org.apache.cassandra.index.sasi.plan.Expression.Bound
-
- inclusiveClose(boolean, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- inclusiveClose(boolean, ByteBuffer[], DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- inclusiveCloseExclusiveOpen(boolean, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- inclusiveCloseExclusiveOpen(boolean, ByteBuffer[], DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- inclusiveEndOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.ClusteringBound
-
- inclusiveEndOf(ClusteringPrefix) - Static method in class 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, ByteBuffer[]) - Static method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- inclusiveOpen(boolean, ByteBuffer[], 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.ClusteringBound
-
- inclusiveStartOf(ClusteringPrefix) - Static method in class org.apache.cassandra.db.ClusteringBound
-
- incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- IncomingFileMessage - Class in org.apache.cassandra.streaming.messages
-
IncomingFileMessage is used to receive the part(or whole) of a SSTable data file.
- IncomingFileMessage(SSTableMultiWriter, FileMessageHeader) - Constructor for class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- IncomingStreamingConnection - Class in org.apache.cassandra.net
-
Thread to consume stream init messages.
- IncomingStreamingConnection(int, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingStreamingConnection
-
- IncomingTcpConnection - Class in org.apache.cassandra.net
-
- IncomingTcpConnection(int, boolean, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
-
- inCondition(ColumnDefinition, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, FieldIdentifier, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, FieldIdentifier, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- incrCounter(Enum<?>, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- incrCounter(String, String, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- incrCreatedHints(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- increaseSlightly() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- increaseSlightly() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- increaseSlightly() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- increaseSlightly() - Method in class org.apache.cassandra.dht.Token
-
Returns a token that is slightly greater than this.
- increment() - Method in class org.apache.cassandra.utils.WrappedInt
-
- incremental_backups - Variable in class org.apache.cassandra.config.Config
-
- INCREMENTAL_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- incrementCounter(Counter, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Increment the counter.
- incrementDroppedMessages(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMessages(MessagingService.Verb, long) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMessages(MessageIn, long) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMessages(MessagingService.Verb, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMessages(MessagingService.Verb, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMutations(Optional<IMutation>, long) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementReadCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Increment the total read count and read rate for this SSTable.
- incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- incrementToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- index(int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- Index - Interface in org.apache.cassandra.index
-
Consisting of a top level Index interface and two sub-interfaces which handle read and write operations,
Searcher and Indexer respectively, this defines a secondary index implementation.
- index - Variable in class org.apache.cassandra.index.internal.CassandraIndexSearcher
-
- index(DecoratedKey, Row) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- index - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
-
- Index(ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- index(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.IndexMemtable
-
- index - Variable in class org.apache.cassandra.index.sasi.plan.Expression
-
- Index.CollatedViewIndexBuildingSupport - Class in org.apache.cassandra.index
-
Default implementation of IndexBuildingSupport
which uses a ReducingKeyIterator
to obtain a
collated view of the data in the SSTables.
- Index.IndexBuildingSupport - Interface in org.apache.cassandra.index
-
Provider of SecondaryIndexBuilder
instances.
- Index.Indexer - Interface in org.apache.cassandra.index
-
Listener for processing events emitted during a single partition update.
- Index.Searcher - Interface in org.apache.cassandra.index
-
Performs the actual index lookup during execution of a ReadCommand.
- INDEX_BUILDER_SUPPORT - Static variable in interface org.apache.cassandra.index.Index
-
Singleton instance of CollatedViewIndexBuildingSupport
, which may be used by any Index
implementation.
- INDEX_ENTRIES_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
The name of the option used to specify that the index is on the collection (map) entries.
- index_interval - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- INDEX_KEYS_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
The name of the option used to specify that the index is on the collection keys.
- INDEX_NOT_FOUND - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- index_summary_capacity_in_mb - Variable in class org.apache.cassandra.config.Config
-
- index_summary_resize_interval_in_minutes - Variable in class org.apache.cassandra.config.Config
-
- indexCfs - Variable in class org.apache.cassandra.index.internal.CassandraIndex
-
- indexCfsMetadata(CFMetaData, IndexMetadata) - Static method in class org.apache.cassandra.index.internal.CassandraIndex
-
Construct the CFMetadata 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
-
- indexColumnFamilyName(IndexMetadata) - Method in class org.apache.cassandra.config.CFMetaData
-
generate a column family name for an index corresponding to the given column.
- indexComparator(boolean) - Method in class org.apache.cassandra.db.ClusteringComparator
-
- indexedColumn - Variable in class org.apache.cassandra.index.internal.CassandraIndex
-
- indexedEntryClustering - Variable in class org.apache.cassandra.index.internal.IndexEntry
-
- indexedKey - Variable in class org.apache.cassandra.index.internal.IndexEntry
-
- IndexedSearchIterator<K,V> - Interface in org.apache.cassandra.utils
-
- IndexedTerm - Class in org.apache.cassandra.index.sasi.sa
-
- IndexedTerm(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.index.sasi.sa.IndexedTerm
-
- IndexEntry - Class in org.apache.cassandra.index.internal
-
Entries in indexes on non-compact tables (tables with composite comparators)
can be encapsulated as IndexedEntry instances.
- IndexEntry(DecoratedKey, Clustering, long, ByteBuffer, Clustering) - Constructor for class org.apache.cassandra.index.internal.IndexEntry
-
- indexerFor(DecoratedKey, PartitionColumns, int, OpOrder.Group, IndexTransaction.Type) - Method in interface org.apache.cassandra.index.Index
-
Creates an new Indexer
object for updates to a given partition.
- indexerFor(DecoratedKey, PartitionColumns, int, OpOrder.Group, IndexTransaction.Type) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- indexerFor(DecoratedKey, PartitionColumns, int, OpOrder.Group, IndexTransaction.Type) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- indexes(Indexes) - Method in class org.apache.cassandra.config.CFMetaData
-
- indexes - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
-
- indexes(PartitionColumns) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- Indexes - Class in org.apache.cassandra.schema
-
For backwards compatibility, in the first instance an IndexMetadata must have
TargetType.COLUMN and its Set of target columns must contain only a single
ColumnIdentifier.
- INDEXES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Indexes.Builder - Class in org.apache.cassandra.schema
-
- indexFile - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- indexFor(ClusteringPrefix, int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- indexId - Variable in exception org.apache.cassandra.schema.UnknownIndexException
-
- indexIdent(List<IndexTarget.Raw>) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- indexIdent(List<IndexTarget.Raw>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- IndexInfo - Class in org.apache.cassandra.io.sstable
-
- IndexInfo(ClusteringPrefix, ClusteringPrefix, long, long, DeletionTime) - Constructor for class org.apache.cassandra.io.sstable.IndexInfo
-
- IndexInfo.Serializer - Class in org.apache.cassandra.io.sstable
-
- indexInfoSerializedSize() - Method in class org.apache.cassandra.db.ColumnIndex
-
- indexInfoSerializer() - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- indexInfoSerializer() - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- indexLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- IndexMemtable - Class in org.apache.cassandra.index.sasi.memory
-
- IndexMemtable(ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.IndexMemtable
-
- indexMetadata() - Method in class org.apache.cassandra.db.ReadCommand
-
Index (metadata) chosen for this query.
- IndexMetadata - Class in org.apache.cassandra.schema
-
An immutable representation of secondary index metadata.
- IndexMetadata.Kind - Enum in org.apache.cassandra.schema
-
- IndexMetadata.Serializer - Class in org.apache.cassandra.schema
-
- IndexMode - Class in org.apache.cassandra.index.sasi.conf
-
- indexName() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- indexName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- IndexName - Class in org.apache.cassandra.cql3
-
- IndexName() - Constructor for class org.apache.cassandra.cql3.IndexName
-
- indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- indexNames - Variable in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
-
- IndexNotAvailableException - Exception in org.apache.cassandra.index
-
Thrown if a secondary index is not currently available.
- IndexNotAvailableException(Index) - Constructor for exception org.apache.cassandra.index.IndexNotAvailableException
-
Creates a new IndexNotAvailableException
for the specified index.
- indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
The index of the item within the list, or its insertion point otherwise.
- indexOfCurrent() - Method in class org.apache.cassandra.utils.btree.BTreeSearchIterator
-
- indexOfCurrent() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
-
- indexOnHeap() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- indexPartition(DecoratedKey, Set<Index>, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
When building an index against existing data in sstables, add the given partition to the index
- indexPath - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- IndexPropDefs - Class in org.apache.cassandra.cql3.statements
-
- IndexPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- indexReadController() - Method in class org.apache.cassandra.db.ReadExecutionController
-
- IndexRegistry - Interface in org.apache.cassandra.index
-
The collection of all Index instances for a base table.
- IndexRestrictions - Class in org.apache.cassandra.cql3.restrictions
-
- IndexRestrictions() - Constructor for class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- indexSamples() - Method in class org.apache.cassandra.db.ColumnIndex
-
- indexSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- IndexState(AbstractSSTableIterator.Reader, ClusteringComparator, RowIndexEntry, boolean, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- indexSummary - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- IndexSummary - Class in org.apache.cassandra.io.sstable
-
- IndexSummary(IPartitioner, Memory, int, Memory, long, int, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
-
- IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder(long, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
Build an index summary builder.
- IndexSummaryBuilder.ReadableBoundary - Class in org.apache.cassandra.io.sstable
-
Represents a boundary that is guaranteed fully readable in the summary, index file and data file.
- IndexSummaryManager - Class in org.apache.cassandra.io.sstable
-
Manages the fixed-size memory pool for index summaries, periodically resizing them
in order to give more memory to hot sstables and less memory to cold sstables.
- IndexSummaryManagerMBean - Interface in org.apache.cassandra.io.sstable
-
- indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Off heap memory used by index summary
- indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Off heap memory used by index summary
- indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- indexSummaryOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- IndexSummaryRedistribution - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryRedistribution(List<SSTableReader>, Map<UUID, LifecycleTransaction>, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- IndexTarget - Class in org.apache.cassandra.cql3.statements
-
- IndexTarget(ColumnIdentifier, IndexTarget.Type) - Constructor for class org.apache.cassandra.cql3.statements.IndexTarget
-
- IndexTarget.Raw - Class in org.apache.cassandra.cql3.statements
-
- IndexTarget.Type - Enum in org.apache.cassandra.cql3.statements
-
- IndexTransaction - Interface in org.apache.cassandra.index.transactions
-
Base interface for the handling of index updates.
- IndexTransaction.Type - Enum in org.apache.cassandra.index.transactions
-
Used to differentiate between type of index transaction when obtaining
a handler from Index implementations.
- indexValue - Variable in class org.apache.cassandra.index.internal.IndexEntry
-
- inDirectory(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The directory where to write the sstables.
- inDirectory(File) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The directory where to write the sstables (mandatory option).
- InetAddressAndPort - Class in org.apache.cassandra.locator
-
A class to replace the usage of InetAddress to identify hosts in the cluster.
- InetAddressSerializer - Class in org.apache.cassandra.serializers
-
- InetAddressSerializer() - Constructor for class org.apache.cassandra.serializers.InetAddressSerializer
-
- InetAddressType - Class in org.apache.cassandra.db.marshal
-
- InfiniteLoopExecutor - Class in org.apache.cassandra.concurrent
-
- InfiniteLoopExecutor(String, InfiniteLoopExecutor.InterruptibleRunnable) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
-
- InfiniteLoopExecutor.InterruptibleRunnable - Interface in org.apache.cassandra.concurrent
-
- info - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
- info(Consumer<String>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
-
- info - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
-
- Info - Class in org.apache.cassandra.tools.nodetool
-
- Info() - Constructor for class org.apache.cassandra.tools.nodetool.Info
-
- info(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- info(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- info(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
-
- info(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
-
- init() - Method in class org.apache.cassandra.auth.AuthCache
-
- init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
-
- init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
-
- init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
-
- init(NonTokenizingOptions, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
-
- init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
-
- init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- init(StandardTokenizerOptions) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- init(StandardTokenizerOptions, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- init(Set<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
Initialize this column index with specific set of SSTables.
- init(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Initialize the client.
- init() - Static method in class org.apache.cassandra.metrics.AuthMetrics
-
- init(Collection<Server>) - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize the Cassandra Daemon based on the given
Commons
Daemon-specific arguments.
- init(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
-
Bind this session to report to specific
StreamResultFuture
and
perform pre-streaming initialization.
- init() - Method in class org.apache.cassandra.utils.MerkleTree
-
Initializes this tree by splitting it until hashdepth is reached,
or until an additional level of splits would violate maxsize.
- init() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Init all MerkleTree's with an even tree distribution.
- init(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Init a selected MerkleTree with an even tree distribution.
- init(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- initCf(CFMetaData, 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.
- INITIAL_HOST_ADDRESS_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- INITIAL_MEM_BUFFER_SIZE - Static variable in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- initial_token - Variable in class org.apache.cassandra.config.Config
-
- INITIAL_VALUE_NANOS - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- initialComparator - Variable in class org.apache.cassandra.db.Memtable
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- initialCompressedBufferLength(int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- initialCondition() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.cassandra.auth.CassandraLoginModule
-
Initialize this LoginModule.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- initializeClientTransports() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- initialized() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- initialized() - Method in class org.apache.cassandra.utils.SigarLibrary
-
- initializeDefaultPort(int) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
- initializeFromMessage(MessageIn<?>) - 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(InetAddress, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
-
- initializeThread() - Method in class org.apache.cassandra.security.SecurityThreadGroup
-
- initializeThread() - Method in interface org.apache.cassandra.security.SecurityThreadGroup.ThreadInitializer
-
- 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
-
- initiate() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up incoming message handler and initiate streaming.
- initiateMutation(Mutation, long, int, int, CommitLogReplayer) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer.MutationInitiator
-
- initiateOnReceivingSide(IncomingStreamingConnection, boolean, int) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up outgoing message handler on receiving side.
- initiator - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- initiator - Variable in class org.apache.cassandra.repair.Validator
-
- initReceivingSide(int, UUID, String, InetAddress, IncomingStreamingConnection, boolean, int, boolean, boolean) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
-
- initServer() - Method in class org.apache.cassandra.service.StorageService
-
- initServer(int) - Method in class org.apache.cassandra.service.StorageService
-
- initSigarLibrary - Static variable in class org.apache.cassandra.service.StartupChecks
-
- injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- inMarker() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- inMarker() - Method in class org.apache.cassandra.cql3.CqlParser
-
- InMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.InMarker
-
- inMarkerForTuple() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- inMarkerForTuple() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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
-
- 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
- InputPosition - Interface in org.apache.cassandra.hints
-
Marker interface for file positions as provided by the various ChecksummedDataReader implementations.
- inputReader - Variable in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- inputVersion - Variable in class org.apache.cassandra.streaming.StreamReader
-
- INRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.INRaw
-
- INRaw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.INRaw
-
- INRestriction(List<ColumnDefinition>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- INRestriction(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- InRestrictionWithMarker(List<ColumnDefinition>, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
-
- InRestrictionWithMarker(ColumnDefinition, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
-
- InRestrictionWithValues(List<ColumnDefinition>, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
-
- InRestrictionWithValues(ColumnDefinition, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
-
- inRowRangeTombstones() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- inRowTombstones - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyDeletionInfo
-
- inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- insertRow(Row) - Method in interface org.apache.cassandra.index.Index.Indexer
-
Notification that a new row was inserted into the Memtable holding the partition.
- insertStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- insertStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- inspectCommitLogThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- inspectJvmOptions - Static variable in class org.apache.cassandra.service.StartupChecks
-
- inspectThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
Certain Throwables and Exceptions represent "Die" conditions for the server.
- inspectThrowable(Throwable, Consumer<Throwable>) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- install() - Static method in class org.apache.cassandra.security.ThreadAwareSecurityManager
-
- instance - Static variable in class org.apache.cassandra.batchlog.BatchlogManager
-
- instance - Static variable in class org.apache.cassandra.cache.ChunkCache
-
- instance - Static variable in class org.apache.cassandra.config.Schema
-
- instance - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- instance - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- instance() - Static method in class org.apache.cassandra.db.context.CounterContext
-
- instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
Deprecated.
- instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BooleanType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.ByteType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DurationType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LongType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.ShortType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.SimpleDateType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
-
- instance - Static variable in class org.apache.cassandra.db.SizeEstimatesRecorder
-
- instance - Static variable in interface org.apache.cassandra.db.StorageHook
-
- instance - Static variable in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- instance - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- instance - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- instance - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- instance - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- instance - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- instance - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- instance - Static variable in class org.apache.cassandra.gms.Gossiper
-
- instance - Static variable in class org.apache.cassandra.hints.HintsService
-
- instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
-
- instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
-
- instance - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- instance - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- instance - Static variable in class org.apache.cassandra.metrics.AuthMetrics
-
- instance - Static variable in class org.apache.cassandra.metrics.ClientMetrics
-
- instance() - Static method in class org.apache.cassandra.net.MessagingService
-
- instance - Static variable in class org.apache.cassandra.serializers.AsciiSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.ByteSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BytesSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DurationSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.ShortSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- instance - Static variable in class org.apache.cassandra.service.CacheService
-
- instance - Static variable in class org.apache.cassandra.service.ClientWarn
-
- instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
-
- instance - Static variable in class org.apache.cassandra.service.MigrationCoordinator
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- instance - Static variable in class org.apache.cassandra.service.PendingRangeCalculatorService
-
- instance - Static variable in class org.apache.cassandra.service.StorageProxy
-
- instance - Static variable in class org.apache.cassandra.service.StorageService
-
- instance - Static variable in interface org.apache.cassandra.streaming.StreamHook
-
- instance - Static variable in class org.apache.cassandra.streaming.StreamManager
-
- instance - Static variable in class org.apache.cassandra.thrift.ThriftSessionManager
-
- instance - Static variable in class org.apache.cassandra.tracing.Tracing
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- instance - Static variable in class org.apache.cassandra.triggers.TriggerExecutor
-
- instance - Static variable in class org.apache.cassandra.utils.Clock
-
Static singleton object that will be instanciated by default with a system clock
implementation.
- instance - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- instance - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
-
- instance - Static variable in class org.apache.cassandra.utils.memory.HeapAllocator
-
- instance - Static variable in class org.apache.cassandra.utils.SigarLibrary
-
- instanceId - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- 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.
- instantiateRebufferer() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
-
- instantiateRebufferer() - Method in interface org.apache.cassandra.io.util.RebuffererFactory
-
- InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
-
Wraps an ICache in requests + hits tracking.
- InstrumentingCache(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
-
- Int32Serializer - Class in org.apache.cassandra.serializers
-
- Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
-
- Int32Type - Class in org.apache.cassandra.db.marshal
-
- integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IntegerInterval - Class in org.apache.cassandra.utils
-
Mutable integer interval class, thread-safe.
- IntegerInterval(int, int) - Constructor for class org.apache.cassandra.utils.IntegerInterval
-
- IntegerInterval(IntegerInterval) - Constructor for class org.apache.cassandra.utils.IntegerInterval
-
- IntegerInterval.Set - Class in org.apache.cassandra.utils
-
A mutable set of closed integer intervals, stored in normalized form (i.e.
- IntegerSerializer - Class in org.apache.cassandra.serializers
-
- IntegerSerializer() - Constructor for class org.apache.cassandra.serializers.IntegerSerializer
-
- IntegerType - Class in org.apache.cassandra.db.marshal
-
- IntegralSA - Class in org.apache.cassandra.index.sasi.sa
-
- IntegralSA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.IntegralSA
-
- inter_dc_stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- inter_dc_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
-
- INTER_DC_THROTTLE_MBITS - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- interDcThrottle - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- InteriorNode() - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- internalClose() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Close the segment file.
- internalClose() - Method in class org.apache.cassandra.db.commitlog.FileDirectSegment
-
- internalClose() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
-
- internalDroppedLatency - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
The dropped latency within node
- internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- internalOpen(Descriptor, Set<Component>, CFMetaData, FileHandle, FileHandle, IndexSummary, IFilter, long, StatsMetadata, SSTableReader.OpenReason, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).
- internalQueryState() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- internalReadForView(DecoratedKey, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
Returns a read command that can be used internally to query all the rows queried by this SELECT for a
give key (used for materialized views).
- internode_authenticator - Variable in class org.apache.cassandra.config.Config
-
- internode_compression - Variable in class org.apache.cassandra.config.Config
-
- internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- internode_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internode_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by any entity wanting to interrogate the status of an endpoint.
- interrupt() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- interruptCompactionFor(Iterable<CFMetaData>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Try to stop all of the compactions for given ColumnFamilies.
- interruptCompactionForCFs(Iterable<ColumnFamilyStore>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
this = this AND other
- intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(ClusteringComparator, List<ByteBuffer>, List<ByteBuffer>) - Method in class org.apache.cassandra.db.Slice
-
Given the per-clustering column minimum and maximum value a sstable contains, whether or not this slice potentially
intersects that sstable or not.
- intersects(List<ByteBuffer>, List<ByteBuffer>) - Method in class org.apache.cassandra.db.Slices
-
Given the per-clustering column minimum and maximum value a sstable contains, whether or not this slices potentially
intersects that sstable or not.
- intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
return true if @param range intersects any of the given @param ranges
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
-
- intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- Interval<C,D> - Class in org.apache.cassandra.utils
-
- Interval(C, C, D) - Constructor for class org.apache.cassandra.utils.Interval
-
- intervalCount() - Method in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- intervalCount() - Method in interface org.apache.cassandra.index.sasi.conf.view.TermTree
-
- intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
-
- intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
-
- IntervalLock - Class in org.apache.cassandra.utils.concurrent
-
This class extends ReentrantReadWriteLock to provide a write lock that can only be acquired at provided intervals.
- IntervalLock(TimeSource) - Constructor for class org.apache.cassandra.utils.concurrent.IntervalLock
-
- intervals() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
- IntervalSet<T extends java.lang.Comparable<T>> - Class in org.apache.cassandra.db.commitlog
-
An immutable set of closed intervals, stored in normalized form (i.e.
- IntervalSet(T, T) - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet
-
Construct new set containing the interval with the given start and end position.
- IntervalSet.Builder<T extends java.lang.Comparable<T>> - Class in org.apache.cassandra.db.commitlog
-
Builder of interval sets, applying the necessary normalization while adding ranges.
- IntervalTree<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- IntervalTree(Collection<I>) - Constructor for class org.apache.cassandra.utils.IntervalTree
-
- IntervalTree.Serializer<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- intValue() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- intValue() - Method in class org.apache.cassandra.cql3.CqlParser
-
- INVALID_FOR_SYSTEM_KEYSPACES - Static variable in enum org.apache.cassandra.auth.Permission
-
Set of Permissions which may never be granted on any system keyspace, or table in a system keyspace, to any role.
- INVALID_INDEX - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- invalidate() - Method in class org.apache.cassandra.auth.AuthCache
-
- invalidate(K) - Method in class org.apache.cassandra.auth.AuthCache
-
- invalidate() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
call when dropping or renaming a CF.
- invalidate(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidate() - Method in class org.apache.cassandra.db.DiskBoundaries
-
- invalidate() - Method in class org.apache.cassandra.db.DiskBoundaryManager
-
- invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Invalidates the ranges containing the given token.
- 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
-
Remove all indexes
- invalidateCachedPartition(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCachedPartition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCachedRings() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- invalidateCounterCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCounterCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateCounterCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- invalidateCounterCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateCounterCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateCounterCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
-
- invalidateCounterCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidateCredentials(String) - Method in interface org.apache.cassandra.auth.PasswordAuthenticator.CredentialsCacheMBean
-
- invalidateDiskBoundaries() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateFile(String) - Method in class org.apache.cassandra.cache.ChunkCache
-
- invalidateKeyCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateKeyCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the key cache; for use after invalidating row cache
- invalidateKeyCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateKeyCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateKeyCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
-
- invalidateKeyCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidatePosition(FileHandle, long) - Method in class org.apache.cassandra.cache.ChunkCache
-
- invalidateRowCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateRowCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateRowCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the row cache; for use after bulk loading via BinaryMemtable
- invalidateRowCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateRowCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateRowCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateRowCache
-
- invalidateRowCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidCrc - Variable in exception org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentReadException
-
- invalidRequest(String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Returns an InvalidRequestException
with the specified message.
- InvalidRequestException - Exception in org.apache.cassandra.exceptions
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
-
- invalids() - Method in class org.apache.cassandra.utils.MerkleTree
-
Returns a lazy iterator of invalid TreeRanges that need to be filled
in order to make the given Range valid.
- invalids() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get an iterator for all the invalids generated by the MerkleTrees.
- 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.ClusteringBound
-
- invert() - Method in class org.apache.cassandra.db.ClusteringBoundary
-
- invert() - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
Returns the inverse of the current bound.
- invert() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
Returns the inverse of the current kind.
- invert() - Method in enum org.apache.cassandra.utils.btree.BTree.Dir
-
- INVERTED_ORDER - Static variable in class org.apache.cassandra.utils.memory.MemoryUtil
-
- invoke(Object, Method, Object[]) - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- invoke() - Method in interface org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanupCallback
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- 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
-
- IRequestScheduler - Interface in org.apache.cassandra.scheduler
-
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
- IResource - Interface in org.apache.cassandra.auth
-
The interface at the core of Cassandra authorization.
- 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
-
- is30() - Method in class org.apache.cassandra.utils.CassandraVersion
-
- IS_DISABLED_MBEAN_REGISTRATION - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
-
- IS_PARTIAL_BIT - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- IS_UNALIGNED - Static variable in class org.apache.cassandra.utils.Architecture
-
- isAborted() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- isAborted() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- isAcceptable(Path) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
-
- isActive - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
pause/resume/getNextBackgroundTask must synchronize.
- isActive() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- isAffectedByMeteredFlusher() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
-
- isAfter(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
- isAggregate() - Method in interface org.apache.cassandra.cql3.functions.Function
-
Checks whether the function is an aggregate function or not.
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeAggregateFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Checks if this Selector
is creating aggregates.
- isAggregateSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates selectors instances that creates aggregates.
- isAlive() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
-
- isAlive() - Method in class org.apache.cassandra.gms.EndpointState
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Failure Detector's knowledge of whether a node is up or
down.
- isAlive - Static variable in interface org.apache.cassandra.net.IAsyncCallback
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- isAnalyzed - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
If IAuthenticator doesn't require authentication, this method may return true.
- isAnyNodeOn30() - Method in class org.apache.cassandra.gms.Gossiper
-
- isAssignable() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
- isAuthSetupComplete - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- isAuthSetupComplete() - Method in class org.apache.cassandra.service.StorageService
-
- isAuthzRequired - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAutoCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isAutoCompactionDisabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAvailable() - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- isAvailable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isAvailable() - Static method in class org.apache.cassandra.utils.NativeLibrary
-
Checks if the library has been successfully linked.
- isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
-
- isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
-
- isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
-
- isBackPressureEnabled() - Method in class org.apache.cassandra.net.MessagingService
-
- isBackPressureEnabled() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Get back-pressure enabled state
- isBatch - Variable in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- isBeta() - Method in enum org.apache.cassandra.transport.ProtocolVersion
-
- isBitSet(K, int) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
-
Returns true
if a key's bit it set at the given index.
- isBlocking() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- isBlockingSignal() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
register to be signalled when a barrier waiting on us is, or maybe, blocking general progress,
so we should try more aggressively to progress
- isBlockingSignal(WaitQueue.Signal) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
wrap the provided signal to also be signalled if the operation gets marked blocking
- isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
-
- isBootstrapMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Check if currently bootstrapping.
- isBootstrapMode() - Method in class org.apache.cassandra.tools.NodeProbe
-
- IsBootstrappingException - Exception in org.apache.cassandra.exceptions
-
- IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
-
- isBound() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
- isBoundary() - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- isBoundary() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
- isBoundary() - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- isBoundary() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- isBoundary() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- isByteOrderComparable - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- isCallableWrtNullable(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
-
- isCalledOnNullInput() - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
-
- isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- 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
-
- isCDCEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isCell() - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
- isCell() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isCell() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- isClean() - Method in class org.apache.cassandra.db.Memtable
-
- isCleanedUp() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- isCleanerAvailable - Static variable in class org.apache.cassandra.io.util.FileUtils
-
- isClientInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isClientMode() - Static method in class org.apache.cassandra.config.Config
-
- isClientOrToolInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isClose(boolean) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- isClose(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
- isClose(boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- isClose(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- isClose(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- isClusteringColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- 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.db.marshal.AbstractType
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isCollectionTombstone() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- isColumnRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the query returns a range of columns.
- isColumnRestrictedByEq(ColumnDefinition) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the specified column is restricted by an EQ restriction.
- isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactionDiskSpaceCheckEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isCompactionDiskSpaceCheckEnabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactTable() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.ElementAddition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.ElementSubtraction
-
- 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.ColumnToCollectionType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- 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
-
- 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.streaming.ProgressInfo
-
- isComplex() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isComposites() - Method in class org.apache.cassandra.schema.IndexMetadata
-
- isCompound() - Method in class org.apache.cassandra.config.CFMetaData
-
- isCompressed() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- isConstant() - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
-
- isContained(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Return true if file is contained in folder
- isContains() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a CONTAINS
.
- isContains() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- isContains() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- isContains() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Checks if the operator of this IndexExpression
is a CONTAINS
operator.
- isContainsKey() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a CONTAINS_KEY
.
- isContainsKey() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Checks if the operator of this IndexExpression
is a CONTAINS_KEY
operator.
- isCounter() - Method in class org.apache.cassandra.config.CFMetaData
-
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isCounter() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isCounter() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isCounter() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCounter() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- isCounterCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isCounterCell() - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- isCounterCell() - Method in class org.apache.cassandra.db.rows.Cell
-
Whether the cell is a counter cell or not.
- isCounterColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isCounterUpdate() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isCqlCompatible(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStoreCQLHelper
-
Whether or not the given metadata is compatible / representable with CQL Language
- isCQLTable() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.MessageIn
-
Whether the message has crossed the node boundary, that is whether it originated from another node.
- isCustom - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- 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.DataResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.DigestResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.ResponseResolver
-
- isDeadState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- isDelete() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks if this type is a delete.
- isDeleted(Clustering, Cell) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns whether the given name/timestamp pair is deleted by one of the tombstone
of this RangeTombstoneList.
- isDense() - Method in class org.apache.cassandra.config.CFMetaData
-
- isDiagnosticSnapshotRequest(SnapshotCommand) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
-
Whether this query is a digest one or not.
- isDigestResponse() - Method in class org.apache.cassandra.db.ReadResponse
-
- isDisjoint() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- isDistinct - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- isDistinct() - Method in class org.apache.cassandra.db.filter.DataLimits
-
- isDone() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- isDone() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- isDone() - Method in interface org.apache.cassandra.db.Slices.InOrderTester
-
- isDone(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.SerializationHelper
-
- isDroppedComplexDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- isDummy() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- isDuration() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isEmpty() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return true if there are no options with values set, false otherwise
- isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
-
- isEmpty() - Method in class org.apache.cassandra.config.Schema
-
Checks whether the current schema is empty.
- isEmpty() - Method in class org.apache.cassandra.cql3.ColumnConditions
-
- isEmpty() - Method in interface org.apache.cassandra.cql3.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.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.LegacyLayout.LegacyRangeTombstoneList
-
- 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 class org.apache.cassandra.db.Mutation
-
- isEmpty() - Method in class org.apache.cassandra.db.PartitionColumns
-
- 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.rows.BaseRowIterator
-
Returns whether the provided iterator has no data.
- isEmpty() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- isEmpty() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- isEmpty() - Method in interface org.apache.cassandra.db.rows.Row
-
Whether the row has no information whatsoever.
- isEmpty() - Method in interface org.apache.cassandra.db.rows.RowIterator
-
Returns whether the provided iterator has no data.
- isEmpty() - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
- isEmpty() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterator
-
Returns whether this iterator has no data (including no deletion data).
- isEmpty - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- isEmpty(ClusteringComparator) - Method in class org.apache.cassandra.db.Slice
-
Return whether the slice is empty.
- isEmpty(ClusteringComparator, ClusteringBound, ClusteringBound) - Static method in class org.apache.cassandra.db.Slice
-
Return whether the slice formed by the two provided bound is empty or not.
- isEmpty() - Method in class org.apache.cassandra.db.Slices
-
Checks if this Slices
is empty.
- isEmpty() - Method in class org.apache.cassandra.db.transform.FilteredRows
-
- isEmpty(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- 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.schema.Indexes
-
- isEmpty() - Method in class org.apache.cassandra.schema.Triggers
-
- isEmpty() - Method in class org.apache.cassandra.schema.Views
-
- isEmpty() - Method in class org.apache.cassandra.service.paxos.Commit
-
Whether this is an empty commit, that is one with no updates.
- isEmpty() - Method in class org.apache.cassandra.streaming.StreamPlan
-
- isEmpty() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- isEmpty(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
-
- isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- isEmpty() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- isEmpty() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.IntervalTree
-
- isEmpty() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true if there are no set bits
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns
true
for types where empty should be handled like
null
like
Int32Type
.
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LongType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- isEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
-
- isEnabled() - Method in class org.apache.cassandra.schema.CompactionParams
-
- isEnabled() - Method in class org.apache.cassandra.schema.CompressionParams
-
Checks if compression is enabled.
- isEnabled(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
-
Returns true
if the options contains the enabled
option and that its value is
true
, otherwise returns false
.
- isEnabled() - Method in class org.apache.cassandra.security.EncryptionContext
-
- isEnd() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- isEnd() - Method in class 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
-
- isEOF() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
-
- isEOF() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- isEOF() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
Since an entire block of compressed data is read off of disk, not just a hint at a time,
we don't report EOF until the decompressed data has also been read completely
- isEOF() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
-
Since an entire block of compressed data is read off of disk, not just a hint at a time,
we don't report EOF until the decompressed data has also been read completely
- isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- isEQ() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a EQ
.
- isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- isEQ() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- ISerializer<T> - Interface in org.apache.cassandra.io
-
- isExactMatch() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
- isExclusive() - Method in class org.apache.cassandra.db.ClusteringBound
-
- isExhausted(DataLimits.Counter) - Method in class org.apache.cassandra.db.filter.DataLimits
-
- isExhausted() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
-
- isExhausted() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
-
- isExhausted() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Whether or not this pager is exhausted, i.e.
- isExistingRole(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- isExistingRole(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Return true is a Role with the given name exists in the system.
- isExpired() - Method in class org.apache.cassandra.db.LivenessInfo
-
- isExpired() - Method in class org.apache.cassandra.db.Memtable
-
- isExpiring() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- 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.
- isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isFailureCallback() - Method in class org.apache.cassandra.net.CallbackInfo
-
- isFailureResponse() - Method in class org.apache.cassandra.net.MessageIn
-
- isFileSize(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
-
- isFilterFullyCoveredBy(ClusteringIndexFilter, DataLimits, CachedPartition, int) - 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
-
- isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isForSSTable() - Method in class org.apache.cassandra.db.SerializationHeader
-
- isForThrift() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- isForThrift() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
-
- isForThrift() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
-
- isForThrift() - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterator
-
Whether that partition iterator is for a thrift queries.
- isForThrift() - Method in class org.apache.cassandra.db.ReadCommand
-
Whether this query is for thrift or not.
- isForThrift() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- isForThrift() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- isForThrift() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- 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
-
- isFrozenCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isFull() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- 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.CFStatement
-
- isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- isGlobal() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- isGlobal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
if this compaction involves several/all tables we can safely check globalCompactionsPaused
in isStopRequested() below
- isGlobal() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- isGlobal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isGlobal() - Method in class org.apache.cassandra.db.view.ViewBuilder
-
- isGlobal() - Method in class org.apache.cassandra.index.SecondaryIndexBuilder
-
- isGlobal() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- isGlobal - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- isGlobal() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isGlobal - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- isGlobalCompactionPaused() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Return whether "global" compactions should be paused, used by ColumnFamilyStore#runWithCompactionsDisabled
a global compaction is one that includes several/all tables, currently only IndexSummaryBuilder
- isGossipActive() - Method in class org.apache.cassandra.service.StorageService
-
- isGossipOnlyMember(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isGossipRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isGossipRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isGossipRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- isIfExists() - Method in interface org.apache.cassandra.cql3.Conditions
-
Checks if this is a IF EXIST condition.
- isIfNotExists() - Method in interface org.apache.cassandra.cql3.Conditions
-
Checks if this is a IF NOT EXIST condition.
- isIN() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a IN
.
- isIN() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- isIN() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- isIN() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- isInBounds(T, Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- isInclusive(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
Checks if the specified bound is inclusive or not.
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TermSlice
-
Checks if this slice boundary is inclusive for the specified type.
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
-
- isInclusive() - Method in class org.apache.cassandra.db.ClusteringBound
-
- isIncremental - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- isIncremental() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isIncremental - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- isIncremental - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isIncremental() - Method in class org.apache.cassandra.streaming.StreamSession
-
- isIncrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.service.StorageService
-
- isIncrementalBackupsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isIndex() - Method in class org.apache.cassandra.config.CFMetaData
-
true if this CFS contains secondary index data.
- isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
true if this CFS contains secondary index data
- isIndex - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isIndexColumnFamily(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
- isIndexColumnFamilyStore(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
- isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- isIndexed() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- isIndexed() - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- isIndexQueryable(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Checks if the specified index is queryable.
- isInitialized() - Method in class org.apache.cassandra.service.StorageService
-
- isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isInLocalDCOnly() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isInProgress() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- isInProgress() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
- isInsert() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks if this type is an insert.
- isInShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
- isInShutdownHook() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- isInterestedIn(String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
-
- isInterestedIn(String) - Method in class org.apache.cassandra.tools.RepairRunner
-
- isInterestedIn(String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
-
- isInternal - Variable in class org.apache.cassandra.service.ClientState
-
- isInterned() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- isJoined() - Method in class org.apache.cassandra.service.StorageService
-
- isJoined() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isJoined() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isJoining() - Method in class org.apache.cassandra.service.StorageService
-
- isJson - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- isKeyCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isKeyCacheSetup() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isKeyRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the query request a range of partition keys.
- isKeys() - Method in class org.apache.cassandra.schema.IndexMetadata
-
- isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isLastLeaf() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- isLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- isLeaf() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
-
- isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isLegacyBatchlogMutation(Mutation) - Static method in class org.apache.cassandra.batchlog.LegacyBatchlogMigrator
-
- isLegacyFile(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- isLeveledSstable - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- isLIKE() - Method in class org.apache.cassandra.cql3.Relation
-
- isLIKE() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- isLIKE() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- isLimitedToOnePartition() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- isLimitedToOnePartition() - Method in class org.apache.cassandra.db.ReadCommand
-
- isLimitedToOnePartition() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- isLinux - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- isListening() - Method in class org.apache.cassandra.net.MessagingService
-
- isLiteral() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- isLiteral - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- isLiteral - Variable in class org.apache.cassandra.index.sasi.plan.Expression
-
- isLive() - Method in interface org.apache.cassandra.db.DeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- isLive() - Method in class org.apache.cassandra.db.DeletionTime
-
Returns whether this DeletionTime is live, that is deletes no columns.
- isLive(Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
- isLive(int) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isLive(int) - Method in class org.apache.cassandra.db.LivenessInfo
-
Whether that info is still live.
- isLive() - Method in class org.apache.cassandra.db.Memtable
-
- isLive() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- isLive(int) - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- isLive(int) - Method in class org.apache.cassandra.db.rows.Cell
-
Whether the cell is live or not given the current time.
- isLive() - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
Wether the deletion is live or not, that is if its an actual deletion or not.
- isLive() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- isLocal(InetAddress) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isLocal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isLocalId() - Method in class org.apache.cassandra.utils.CounterId
-
- isLocalSystemKeyspace(String) - Static method in class org.apache.cassandra.config.SchemaConstants
-
- isLocalVersion(UUID) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- isLowerSatisfiedBy(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- isMap() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
Checks if this collection is Map.
- isMarkedCompacted() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isMinimum() - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in interface org.apache.cassandra.db.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.utils.DefaultValue
-
- isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMoving() - Method in class org.apache.cassandra.service.StorageService
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.ListType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.MapType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.SetType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.UserType
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if this relation apply to multiple columns.
- isMultiColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- isMultiColumn() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- isNamesQuery() - Method in class org.apache.cassandra.db.DataRange
-
Whether the underlying clustering index filter is a names filter or not.
- isNamesQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- 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.UDAggregate
-
- isNative() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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.
- isNoCompactMode() - Method in class org.apache.cassandra.service.ClientState
-
- isNormal() - Method in class org.apache.cassandra.service.StorageService
-
- 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(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- isNullOrEmpty(AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- isObsolete(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
-
- isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
indicates if the reader has been marked for obsoletion
- isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- isObsolete() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- isOffline() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
-
- isOffline() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- isOffline() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
-
- isOldestLiveGroup() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- isOnToken() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isOnToken() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- isOpen(boolean) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- isOpen(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
- isOpen(boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- isOpen(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- isOpen(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
-
- isOpen() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- isOpen() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Checks whether the socket is connected.
- isOutgoingConnected() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- isOutOfDate() - Method in class org.apache.cassandra.db.DiskBoundaries
-
check if the given disk boundaries are out of date due not being set or to having too old diskVersion/ringVersion
- isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- isOverlapping(RangeIterator<K, D>, RangeIterator<K, D>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- isOverlapping(K, K, RangeIterator<K, D>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
Ranges are overlapping the following cases:
* When they have a common subrange:
min b.current max b.max
+---------|--------------+------------|
b.current min max b.max
|--------------+---------+------------|
min b.current b.max max
+----------|-------------|------------+
If either range is empty, they're disjoint.
- isPackageAllowed(String) - Method in class org.apache.cassandra.security.SecurityThreadGroup
-
- isPaging() - Method in class org.apache.cassandra.db.DataRange
-
Whether the data range is for a paged request or not.
- isPaging() - Method in class org.apache.cassandra.db.DataRange.Paging
-
- isPartial() - Method in class org.apache.cassandra.index.sasi.sa.IndexedTerm
-
- isPartial() - Method in class org.apache.cassandra.index.sasi.Term
-
- isPartial() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- isPartitionKey() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isPartitionKeyRestrictionsOnToken() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the restrictions on the partition key are token restrictions.
- isPartOfCellName(boolean, boolean) - Method in class org.apache.cassandra.config.ColumnDefinition
-
Whether the name of this definition is serialized in the cell nane, i.e.
- isPastCurrentBlock() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- isPrefix(K, K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
-
Returns true
if the second argument is a
prefix of the first argument.
- isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
-
- isPresent(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
-
- 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.config.ColumnDefinition
-
- isPrimaryKeyKind() - Method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
- isPrimaryRange() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isPullRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isRangeTombstoneMarker() - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
- isReceiving() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- 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) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- isRegistered(String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- isRegistered(String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
-
- isRegistered(String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
-
- isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
-
- isRegular() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isRepaired(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- isRepaired() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isReplacingSameAddress() - Static method in class org.apache.cassandra.service.StorageService
-
- isReplicatedSystemKeyspace(String) - Static method in class org.apache.cassandra.config.SchemaConstants
-
- isRestricted(ColumnDefinition) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- isReversed() - Method in class org.apache.cassandra.db.DataRange
-
Whether the underlying ClusteringIndexFilter
is reversed or not.
- isReversed() - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
-
- isReversed() - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
Whether the filter query rows in reversed clustering order or not.
- isReversed() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isReversed() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isReversed() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- isReversed() - Method in class org.apache.cassandra.db.ReadCommand
-
Whether the underlying ClusteringIndexFilter
is reversed or not.
- isReversed - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- isReversed() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- isReversedType() - Method in class org.apache.cassandra.cql3.ColumnSpecification
-
- isReverseOrder() - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
-
- isReverseOrder() - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
-
- isReverseOrder - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- isReverseOrder() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- isReverseOrder() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
-
Whether or not the rows returned by this iterator are in reversed
clustering order.
- isReverseOrder() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- isReverseOrder() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
-
- isReverseOrder() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- isReverseOrder() - Method in class org.apache.cassandra.db.transform.BaseRows
-
- isReverseOrder() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- isReverseOrder() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- 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
-
- isRowAtom(CFMetaData) - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
Whether the atom is one that becomes part of a
Row
in the new storage engine, meaning it is either
as cell or a legacy range tombstone that covers a single row, or parts of one.
- isRowAtom(CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isRowAtom(CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- isRowCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isRowDeletion(CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- isRpcReady() - Method in class org.apache.cassandra.gms.EndpointState
-
- isRpcReady(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Returns whether the server is currently running.
- isRunning() - Method in class org.apache.cassandra.service.NativeTransportService
-
- isRunning() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- isRunning() - Method in class org.apache.cassandra.transport.Server
-
- isSafeForStartup(InetAddress, UUID, boolean, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
Check if this node can safely be started and join the ring.
- isSameVersion(UUID) - Method in class org.apache.cassandra.config.Schema
-
Checks whether the given schema version is the same as the current local schema
version, either the 3.0 compatible or "real" one.
- 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(CFMetaData, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
-
- isSatisfiedBy(CFMetaData, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Returns whether the provided row satisfied this expression or not.
- isSatisfiedBy(CFMetaData, DecoratedKey, Row, int) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Whether the provided row in the provided partition satisfies this filter.
- isSatisfiedBy(CFMetaData, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
-
- isSatisfiedBy(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- isSatisfiedByValue(ByteBuffer, Cell, AbstractType<?>, Operator) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- 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.
- 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
-
- isSerializationCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- 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.SEPExecutor
-
- isShutDown() - Method in class org.apache.cassandra.hints.HintsService
-
Returns true in case service is shut down.
- isShutdown() - Method in class org.apache.cassandra.service.StorageService
-
- isSignaled() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- isSignalled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
- isSilent() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- isSilentShutdownState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- isSimple() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isSimpleSelectorFactory(int) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates Selector
s that simply return the specified column.
- isSlice() - Method in enum org.apache.cassandra.cql3.Operator
-
Checks if this operator is a slice operator.
- isSlice() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a Slice
(GT, GTE, LTE, LT).
- isSlice() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- isSlice() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- isSlice() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
- isSlow() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- isSlow() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- isSmallerOrEqualTo(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
-
- isSmallerThan(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
-
- isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isSorted() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- isSorted() - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Whether the builder is a sorted one or not.
- isSparse() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
-
- ISSTableScanner - Interface in org.apache.cassandra.io.sstable
-
An ISSTableScanner is an abstraction allowing multiple SSTableScanners to be
chained together under the hood.
- ISSTableSerializer<T> - Interface in org.apache.cassandra.io
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
Check whether a value retrieved from an index is still valid by comparing it to current row from the base table.
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
-
- isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
-
- isStart() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- isStart() - Method in class org.apache.cassandra.db.ClusteringBound
-
- isStart() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
- isStartInclusive() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- isStartInclusive() - Method in class org.apache.cassandra.dht.Bounds
-
- isStartInclusive() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- isStartInclusive() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- isStartInclusive() - Method in class org.apache.cassandra.dht.Range
-
- isStarting() - Method in class org.apache.cassandra.service.StorageService
-
- isStarting() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns whether the storage service is starting or not
- isStarting() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isStatic() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isStatic() - Method in interface org.apache.cassandra.db.LegacyLayout.LegacyAtom
-
- isStatic - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyBound
-
- isStatic() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- isStatic() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- isStatic() - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- isStatic() - Method in interface org.apache.cassandra.db.rows.Row
-
Whether the row correspond to a static row or not.
- isStatic(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- isStaticCompactTable() - Method in class org.apache.cassandra.config.CFMetaData
-
- isStaticName(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- isStillAllocating() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- isSubDirectory(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- isSubrangeRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isSuccess() - Method in class org.apache.cassandra.streaming.StreamSession
-
Return if this session completed successfully.
- isSuccessful() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- issue() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
Issues (seals) the barrier, meaning no new operations may be issued against it, and expires the current
Group.
- isSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Checks the user's superuser status.
- isSuper(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- isSuper(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Return true if there exists a Role with the given name that also has
superuser status.
- isSuper() - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperColumnKeyColumn(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperColumnMapColumn(ColumnDefinition) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
- isSuperColumnValueColumn(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperuser - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
Check if this type of restriction is supported for by the specified index.
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
Check if this type of restriction is supported by the specified index.
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
-
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- isSupportedBy(ColumnDefinition, Index) - Method in class org.apache.cassandra.cql3.restrictions.TermSlice
-
Check if this TermSlice
is supported by the specified index.
- isSupportedBy(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
-
- isSurveyMode() - Method in class org.apache.cassandra.service.StorageService
-
- isSuspect - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isSystem() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Some internal operations are performed on behalf of Cassandra itself, in those cases
the system user should be used where an identity is required
see CreateRoleStatement#execute() and overrides of SchemaAlteringStatement#grantPermissionsToCreator()
- isSystemKeyspace(String) - Static method in class org.apache.cassandra.config.SchemaConstants
-
- isTableLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isTerminated() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- isThriftCompatible() - Method in class org.apache.cassandra.config.CFMetaData
-
Returns whether this CFMetaData can be returned to thrift.
- isThriftServerRunning() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isThrowOnOverload() - Method in class org.apache.cassandra.transport.Connection
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isTimeToLiveSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- 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.LegacyLayout.LegacyCell
-
- 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
-
- isTraced() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
-
Indicates if the current thread's execution is being traced.
- isTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- isTTLSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates TTL
selectors instances.
- isTuple() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isTuple() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isTuple() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- isTuple() - Method in class org.apache.cassandra.db.marshal.UserType
-
- isUDT() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isUDT() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isUDT() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- isUDT() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isUDT() - Method in class org.apache.cassandra.db.marshal.UserType
-
- isUnlimited() - Method in class org.apache.cassandra.db.filter.DataLimits
-
- isUnreadable(File) - Static method in class org.apache.cassandra.db.DisallowedDirectories
-
Tells whether or not the directory is disallowed for reads.
- isUnrestricted() - Method in class org.apache.cassandra.db.DataRange
-
Whether this DataRange
queries everything (has no restriction neither on the
partition queried, nor within the queried partition).
- isUnrestricted() - Method in class org.apache.cassandra.db.DataRange.Paging
-
- isUnsafeSystem() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isUnwritable(File) - Static method in class org.apache.cassandra.db.DisallowedDirectories
-
Tells whether or not the directory is disallowed for writes.
- isUpdate() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks if this type is an update.
- isUpdate(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Checks if a context is an update (see createUpdate() for justification).
- isUpperSatisfiedBy(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- isUserDefined() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- isValid(InetAddress) - Method in class org.apache.cassandra.batchlog.BatchlogManager.EndpointFilter
-
- isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- isValid(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.index.sasi.utils.TypeUtil
-
- isValid(ChannelProxy) - Method in class org.apache.cassandra.io.util.MmappedRegions
-
- isValidFile(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- 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
-
- isVersion2x() - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
True if runtime Hadoop version is 2.x, false otherwise.
- isView() - Method in class org.apache.cassandra.config.CFMetaData
-
- isView() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isViewBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isViewStatusReplicated(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isWellFormed(Object[], Comparator<? extends Object>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- isWildcard() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- isWindows - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
Returns whether for a range query doing a query against merged is likely
to be faster than 2 sequential queries, one against l1 followed by one against l2.
- isWrapAround() - Method in class org.apache.cassandra.db.DataRange
-
Whether the range queried by this DataRange
actually wraps around.
- isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
-
Tells if the given range is a wrap around.
- isWrapAround() - Method in class org.apache.cassandra.dht.Range
-
- isWritetime - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
-
- isWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates writetime
selectors instances.
- iterable(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterable(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterable(Object[], int, int, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterator() - Method in class org.apache.cassandra.cql3.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.filter.RowFilter
-
- iterator() - Method in class org.apache.cassandra.db.PartitionColumns
-
- 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.partitions.PartitionUpdate
-
Returns an iterator that iterates over the rows of this update in clustering order.
- iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator(boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator(Slice, boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- iterator() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- iterator() - Method in class org.apache.cassandra.db.view.TableViews
-
- iterator() - Method in class org.apache.cassandra.index.sasi.conf.view.View
-
- iterator() - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
-
- iterator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- iterator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.OnDiskSuperBlock
-
- iterator() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- iterator(Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
-
- iterator() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
-
- iterator(DecoratedKey, Slices, ColumnFilter, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator(FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- iterator(DecoratedKey, Slices, ColumnFilter, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator(FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- iterator() - Method in class org.apache.cassandra.locator.PendingRangeMaps
-
- iterator() - Method in class org.apache.cassandra.schema.Functions
-
- iterator() - Method in class org.apache.cassandra.schema.Indexes
-
- iterator() - Method in class org.apache.cassandra.schema.Keyspaces
-
- iterator() - Method in class org.apache.cassandra.schema.Tables
-
- iterator() - Method in class org.apache.cassandra.schema.Triggers
-
- iterator() - Method in class org.apache.cassandra.schema.Types
-
- iterator() - Method in class org.apache.cassandra.schema.Views
-
- iterator() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
-
- iterator(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterator(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterator(Object[], int, int, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- iterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- iterator() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- iterator() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- iterator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
- iterator() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get an iterator of all ranges and their MerkleTrees.
- iterator() - Method in class org.apache.cassandra.utils.MerkleTrees.TreeRangeIterator
-
- iteratorAt(ByteBuffer, OnDiskIndex.IteratorOrder, boolean) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- iterators() - Method in interface org.apache.cassandra.utils.IMergeIterator
-
- iterators - Variable in class org.apache.cassandra.utils.MergeIterator
-
- iterators() - Method in class org.apache.cassandra.utils.MergeIterator
-
- iteratorType - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- IteratorWithLowerBound<In> - Interface in org.apache.cassandra.utils
-
- ITransportFactory - Interface in org.apache.cassandra.thrift
-
Transport factory for establishing thrift connections from clients to a remote server.
- ITrigger - Interface in org.apache.cassandra.triggers
-
- iv_length - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- IVerbHandler<T> - Interface in org.apache.cassandra.net
-
IVerbHandler provides the method that all verb handlers need to implement.
- IVersionedSerializer<T> - Interface in org.apache.cassandra.io
-
- M - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- M - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- M - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- M - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- mA() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- main(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- main(String[]) - Static method in class org.apache.cassandra.tools.BulkLoader
-
- main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
-
- main(String...) - Static method in class org.apache.cassandra.tools.NodeTool
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
-
Given arguments specifying an SSTable, and optionally an output file, export the contents of the SSTable to JSON.
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableLevelResetter
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableOfflineRelevel
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableRepairedAtSetter
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneScrubber
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneSplitter
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneSSTableUtil
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneUpgrader
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneVerifier
-
- main(String[]) - Static method in class org.apache.cassandra.transport.Client
-
- main(String[]) - Static method in class org.apache.cassandra.utils.DynamicList
-
- major - Variable in class org.apache.cassandra.utils.CassandraVersion
-
- MajorLeveledCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
-
- MajorLeveledCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
-
- MajorLeveledCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
-
Deprecated.
- MajorLeveledCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
-
- make(ByteBuffer...) - Static method in interface org.apache.cassandra.db.Clustering
-
- make(Object...) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Creates a row clustering based on the clustering values.
- make(CFMetaData, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.SerializationHeader
-
- make(ClusteringBound, ClusteringBound) - Static method in class org.apache.cassandra.db.Slice
-
- make(ClusteringComparator, Object...) - Static method in class org.apache.cassandra.db.Slice
-
- make(Clustering) - Static method in class org.apache.cassandra.db.Slice
-
- make(Clustering, Clustering) - Static method in class org.apache.cassandra.db.Slice
-
- makeArgSpec(String, String, Function, int) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
-
- makeBoundary(boolean, ClusteringBound, ClusteringBound, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- makeCollectionReceiver(ColumnSpecification, boolean) - Method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
- makeCollectionReceiver(ColumnSpecification, boolean) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- makeColumnFilter() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- makeCountFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
-
Creates a COUNT function for the specified type.
- makeCreateAggregateMutation(KeyspaceMetadata, UDAggregate, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateFunctionMutation(KeyspaceMetadata, UDFunction, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateKeyspaceMutation(String, KeyspaceParams, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateKeyspaceMutation(KeyspaceMetadata, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateTableMutation(KeyspaceMetadata, CFMetaData, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateTypeMutation(KeyspaceMetadata, UserType, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeCreateViewMutation(KeyspaceMetadata, ViewDefinition, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeDataRequests(Iterable<InetAddress>) - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
- makeDigest(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
-
- makeDigestRequests(Iterable<InetAddress>) - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
- makeDropAggregateMutation(KeyspaceMetadata, UDAggregate, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeDropFunctionMutation(KeyspaceMetadata, UDFunction, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeDropKeyspaceMutation(KeyspaceMetadata, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeDropTableMutation(KeyspaceMetadata, CFMetaData, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeDropViewMutation(KeyspaceMetadata, ViewDefinition, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeFilter() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- makeFilter() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.SinglePartitionSliceBuilder
-
- makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- makeIndexClustering(ByteBuffer, Clustering) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
-
- makeInternalOptions(ParsedStatement.Prepared, Object[]) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- makeIterator(ReadCommand) - Method in class org.apache.cassandra.db.ReadResponse
-
- makeLegacyComparator(CFMetaData) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- makeLegacyDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- makeLimits() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- makeMaxFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
-
Creates a MAX function for the specified type.
- makeMinFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
-
Creates a MIN function for the specified type.
- makeMutation() - Method in class org.apache.cassandra.service.paxos.Commit
-
- makeMutationMessage() - Method in class org.apache.cassandra.db.CounterMutation
-
- makePartitionIterator(ColumnFilter, DataRange, boolean) - Method in class org.apache.cassandra.db.Memtable
-
- makeRangeTombstone(ClusteringComparator, Clustering) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeRangeTombstone(Slice) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeRowBounds(Token, Token) - Static method in class org.apache.cassandra.dht.Bounds
-
Compute a bounds of keys corresponding to a given bounds of token.
- makeRowIterator(ColumnFamilyStore, SSTableReader, DecoratedKey, Slices, ColumnFilter, boolean, boolean, SSTableReadsListener) - Method in interface org.apache.cassandra.db.StorageHook
-
- makeRowIteratorWithLowerBound(ColumnFamilyStore, DecoratedKey, SSTableReader, ClusteringIndexFilter, ColumnFilter, boolean, int, boolean, SSTableReadsListener) - Method in interface org.apache.cassandra.db.StorageHook
-
- makeRowRange(Token, Token) - Static method in class org.apache.cassandra.dht.Range
-
Compute a range of keys corresponding to a given range of token.
- makeRowRange(Range<Token>) - Static method in class org.apache.cassandra.dht.Range
-
- makeToBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- makeUnflushable() - Method in class org.apache.cassandra.db.Memtable
-
For testing only.
- makeUpdatedType(UserType, KeyspaceMetadata) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- makeUpdates(FilteredPartition) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- makeUpdates(FilteredPartition) - Method in interface org.apache.cassandra.service.CASRequest
-
The updates to perform of a CAS success.
- makeUpdateTableMutation(KeyspaceMetadata, CFMetaData, CFMetaData, long) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeUpdateViewMutation(Mutation.SimpleBuilder, ViewDefinition, ViewDefinition) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- makeWithoutStats(CFMetaData) - Static method in class org.apache.cassandra.db.SerializationHeader
-
- manager - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- map(CQL3Type.Raw, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- map - Variable in class org.apache.cassandra.cql3.Maps.Value
-
- map(FileChannel.MapMode, long, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- map(ChannelProxy, CompressionMetadata) - Static method in class org.apache.cassandra.io.util.MmappedRegions
-
- map(ChannelProxy, long) - Static method in class org.apache.cassandra.io.util.MmappedRegions
-
- mapLiteral() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- mapLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
-
- MappedBuffer - Class in org.apache.cassandra.index.sasi.utils
-
- MappedBuffer(RandomAccessReader) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- MappedBuffer(ChannelProxy) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- MappedBuffer(ChannelProxy, int) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- Maps - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for maps.
- Maps.AdderByKey - Class in org.apache.cassandra.cql3
-
- 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.SubtracterByKey - Class in org.apache.cassandra.cql3
-
- Maps.Value - Class in org.apache.cassandra.cql3
-
- MapSerializer<K,V> - Class in org.apache.cassandra.serializers
-
- MapType<K,V> - Class in org.apache.cassandra.db.marshal
-
- mark() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- mark() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- mark() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- mark - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The current mark position.
- mark(int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Sets a mark position in this ByteArrayInputStream.
- mark() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- mark(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- mark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- mark() - Method in interface org.apache.cassandra.io.util.RewindableDataInput
-
- mark() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- mark(int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- mark() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- mark() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- mark() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Mark the occurrence of an event.
- mark(long) - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Mark the occurrence of a given number of events.
- markAllCompacting(OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markAllIndexesRemoved() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Called when dropping a Table
- markAsShutdown(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is used to mark a node as shutdown; that is it gracefully exited on its own and told us about it
- markBlocking() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
Mark all prior operations as blocking, potentially signalling them to more aggressively make progress
- markClean(UUID, CommitLogPosition, CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Marks the ColumnFamily specified by cfId as clean for this log segment.
- markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.Cell
-
- markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.ColumnData
-
- markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- markCounterLocalToBeCleared() - Method in interface org.apache.cassandra.db.rows.Row
-
Returns a copy of this row where all counter cells have they "local" shard marked for clearing.
- markDataSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- markDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- markedForDeleteAt() - Method in class org.apache.cassandra.db.DeletionTime
-
A timestamp (typically in microseconds since the unix epoch, although this is not enforced) after which
data should be considered deleted.
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
-
- Marker(int) - Constructor for class org.apache.cassandra.cql3.Json.Marker
-
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
-
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
-
- marker - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
-
- marker - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
-
- marker - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestrictionWithMarkers
-
- 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
-
- markerForTuple() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- markerForTuple() - Method in class org.apache.cassandra.cql3.CqlParser
-
- markFailure() - Method in class org.apache.cassandra.metrics.AuthMetrics
-
- markFlushing(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- markIndexBuilt(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Marks the specified index as build.
- markIndexRemoved(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Marks the specified index as removed.
- markIndexSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- markLocalToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Mark context to delete local references afterward.
- markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markObsolete() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- markObsolete(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Mark the sstable as obsolete, i.e., compacted into newer sstables.
- markProtocolException() - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- markRequestDiscarded() - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- markSSTablesRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Mark sstables repairing - either all sstables or only the unrepaired ones depending on
whether this is an incremental or full repair
- markSuccess() - Method in class org.apache.cassandra.metrics.AuthMetrics
-
- markSupported() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Indicates whether this stream supports the mark()
and
reset()
methods.
- markSupported() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- markSupported() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- markSupported() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- markSupported() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- markSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- markUnknownException() - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- markUnreadable(String) - Method in class org.apache.cassandra.db.DisallowedDirectories
-
- markUnreadable(String) - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
-
- markUnwritable(String) - Method in class org.apache.cassandra.db.DisallowedDirectories
-
- markUnwritable(String) - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
-
- MarshalException - Exception in org.apache.cassandra.serializers
-
- MarshalException(String) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- match(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.View
-
- match(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.conf.view.View
-
- matchesViewFilter(DecoratedKey, Row, int) - Method in class org.apache.cassandra.db.view.View
-
Whether a given base row matches the view filter (and thus if is should have a corresponding entry).
- max - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- max - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
-
- max() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- max - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- max() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
-
- max() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
-
- max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- max - Variable in class org.apache.cassandra.utils.Interval
-
- max() - Method in class org.apache.cassandra.utils.IntervalTree
-
- MAX_BUFFER_SIZE - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
-
- MAX_CELL_NAME_LENGTH - Static variable in class org.apache.cassandra.db.LegacyLayout
-
- MAX_COALESCED_MESSAGES - Static variable in class org.apache.cassandra.net.OutboundTcpConnection
-
- MAX_DELETION_TIME - Static variable in class org.apache.cassandra.db.rows.Cell
-
- MAX_FAILED_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- max_hints_delivery_threads - Variable in class org.apache.cassandra.config.Config
-
- max_hints_file_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- MAX_JOB_THREADS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- MAX_MEM_BUFFER_SIZE - Static variable in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- max_mutation_size_in_kb - Variable in class org.apache.cassandra.config.Config
-
- MAX_OFFSET - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- MAX_OUTSTANDING_REPLAY_BYTES - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- MAX_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_SPILL_FILE_SIZE - Static variable in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- MAX_SSTABLE_AGE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
Deprecated.
- max_streaming_retries - Variable in class org.apache.cassandra.config.Config
-
- MAX_TERM_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- MAX_TTL - Static variable in class org.apache.cassandra.cql3.Attributes
-
If this limit is ever raised, make sure @Integer.MAX_VALUE
is not allowed,
as this is used as a flag to represent expired liveness.
- MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- max_value_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
Max size of values in SSTables, in MegaBytes.
- MAX_WINDOW_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- maxAge - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- maxBucketsPerElement(long) - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Calculates the maximum number of buckets per element that this implementation
can support.
- maxBytesForLevel(int, long) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- maxBytesForLevel(int, int, long) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- maxClusteringValues - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- maxCompactionFlushMemoryInBytes - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- maxCompactionThreshold() - Method in class org.apache.cassandra.schema.CompactionParams
-
- maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
maxDataAge is a timestamp in local server time (e.g.
- maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- maxFailures - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- maxFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
MAX function for counter column values.
- MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- MAXIMUM_EXPIRATION_DATE_EXCEEDED_REJECT_MESSAGE - Static variable in class org.apache.cassandra.db.ExpirationDateOverflowHandling
-
- MAXIMUM_EXPIRATION_DATE_EXCEEDED_WARNING - Static variable in class org.apache.cassandra.db.ExpirationDateOverflowHandling
-
- maximumLiveCellsPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- maximumTombstonesPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- maxIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- maxIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- maxIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
-
- maxKey - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- maxKey() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- maxKey() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- maxKeyBound() - Method in class org.apache.cassandra.dht.Token
-
- maxLeft(AbstractBounds.Boundary<T>, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- maxLeft(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- 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.SEPMetrics
-
Maximum number of threads before it will start queuing tasks
- maxPoolSize - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Maximum number of threads before it will start queuing tasks
- 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.
- maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
-
- maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
-
- maxsize(Range<Token>, int) - Method in class org.apache.cassandra.utils.MerkleTrees
-
- maxSSTableAge - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
Deprecated.
- maxSSTableBytes - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- MaxSSTableSizeWriter - Class in org.apache.cassandra.db.compaction.writers
-
- MaxSSTableSizeWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, int) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
-
- MaxSSTableSizeWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
-
Deprecated.
- MaxSSTableSizeWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
-
- maxTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- maxTerm() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- maxTerm() - Method in class org.apache.cassandra.index.sasi.sa.TermIterator
-
- maxTerm() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- maxTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
-
- maxTimestamp() - Method in interface org.apache.cassandra.db.DeletionInfo
-
- maxTimestamp() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- maxTimestamp() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
The maximum timestamp used in this update.
- maxTimestamp() - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- maxTimestamp() - Method in class org.apache.cassandra.db.rows.ColumnData
-
- maxTimestamp() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- maxTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- maxTimestampAscending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- maxTimestampDescending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- maxTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns the biggest possible type 1 UUID having the provided timestamp.
- maxTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
- maxTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
Set the max allowed token length.
- maxTTL - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- maxWindowSize - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- maxWorkers - Variable in class org.apache.cassandra.concurrent.SEPExecutor
-
- maybeAddEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- maybeAddEntry(DecoratedKey, long, long, long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- maybeAddLatency(IAsyncCallback, InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
-
Track latency information for the dynamic snitch
- mayBeAffectedBy(DecoratedKey, Row) - Method in class org.apache.cassandra.db.view.View
-
Whether the view might be affected by the provided update.
- maybeApplyExpirationDateOverflowPolicy(CFMetaData, int, boolean) - Static method in class org.apache.cassandra.db.ExpirationDateOverflowHandling
-
- maybeArchive(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- maybeArchive(String, String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
Differs from the above because it can be used on any file, rather than only
managed commit log segments (and thus cannot call waitForFinalSync), and in
the treatment of failures.
- maybeClearCounterValue(ByteBuffer) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- maybeCorrectResource(IResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- maybeExecuteImmediately(Runnable) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
-
- maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- maybeFail(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
-
- maybeFail(Throwable, Class<T>) - Static method in class org.apache.cassandra.utils.Throwables
-
- maybeFinishShadowRound(InetAddress, boolean, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
- 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.
- 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.
- maybeQuote(String) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- maybeRefreshOverlaps() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- maybeReload(CFMetaData) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- maybeReloadDiskBoundaries() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
Checks if the disk boundaries changed and reloads the compaction strategies
to reflect the most up-to-date disk boundaries.
- maybeResetTraceSessionWrapper(Runnable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- maybeRestoreArchive() - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- maybeSnapshot(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- maybeSwitchWriter(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Guaranteed to be called before the first call to realAppend.
- maybeTryAdditionalReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
Perform additional requests if it looks like the original will time out.
- maybeTryAdditionalReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor.NeverSpeculatingReadExecutor
-
- maybeValidateIndex() - Method in class org.apache.cassandra.db.ReadCommand
-
If the index manager for the CFS determines that there's an applicable
2i that can be used to execute this command, call its (optional)
validation method to check that nothing in this command's parameters
violates the implementation specific validation rules.
- maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- maybeWaitForSync(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- maybeWrap(ChunkReader) - Static method in class org.apache.cassandra.cache.ChunkCache
-
- maybeWrap(UnfilteredPartitionIterator, CFMetaData, int) - Static method in class org.apache.cassandra.thrift.ThriftResultsMerger
-
- maybeWrap(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.thrift.ThriftResultsMerger
-
- mayContainDataBefore(CommitLogPosition) - Method in class org.apache.cassandra.db.Memtable
-
- mayHaveTombstones() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Whether the sstable may contain tombstones or if it is guaranteed to not contain any.
- 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.
- mB() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mbean(String) - Static method in class org.apache.cassandra.auth.JMXResource
-
- mbean() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- mbean() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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.HintedHandOffManager
-
Deprecated.
- MBEAN_NAME - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.gms.Gossiper
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.net.MessagingService
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.service.CacheService
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.service.CassandraDaemon
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.service.GCInspector
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.service.StorageProxy
-
- MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- MBEAN_REGISTRATION_CLASS - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
-
- mbean_return() - Constructor for class org.apache.cassandra.cql3.Cql_Parser.mbean_return
-
- 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
-
- mBOOLEAN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mD() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- MD5Digest - Class in org.apache.cassandra.utils
-
The result of the computation of an MD5 digest.
- mDIGIT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mDURATION() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mDURATION_ISO_8601_PERIOD_DESIGNATORS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mDURATION_ISO_8601_TIME_DESIGNATORS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mDURATION_ISO_8601_WEEK_PERIOD_DESIGNATOR() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mDURATION_UNIT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- MEAN_LIFETIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- meanPartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Size of the smallest compacted partition
- meanRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Returns the mean rate of events per second since this object was created.
- measure(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- measureDeep(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- memAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- MemIndex - Class in org.apache.cassandra.index.sasi.memory
-
- MemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.MemIndex
-
- 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
-
- MEMORY_USAGE_THRESHOLD - Static variable in class org.apache.cassandra.utils.memory.BufferPool
-
- MemoryInputStream - Class in org.apache.cassandra.io.util
-
- MemoryInputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
-
- MemoryInputStream(Memory, int) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
-
- MemoryMappedSegment - Class in org.apache.cassandra.db.commitlog
-
- MemoryOutputStream - Class in org.apache.cassandra.io.util
-
This class provides a way to stream the writes into the
Memory
- MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
-
- 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
-
- mEMPTY_QUOTED_NAME() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- Memtable - Class in org.apache.cassandra.db
-
- Memtable(AtomicReference<CommitLogPosition>, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
-
- Memtable(CFMetaData) - Constructor for class org.apache.cassandra.db.Memtable
-
- Memtable(CFMetaData, long) - Constructor for class org.apache.cassandra.db.Memtable
-
- memtable - Variable in class org.apache.cassandra.notifications.MemtableDiscardedNotification
-
- memtable - Variable in class org.apache.cassandra.notifications.MemtableSwitchedNotification
-
- Memtable.LastCommitLogPosition - Class in org.apache.cassandra.db
-
- Memtable.MemtableUnfilteredPartitionIterator - Class in org.apache.cassandra.db
-
- memtable_allocation_type - Variable in class org.apache.cassandra.config.Config
-
- memtable_cleanup_threshold - Variable in class org.apache.cassandra.config.Config
-
- memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
-
- memtable_heap_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- memtable_offheap_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- MemtableAllocator - Class in org.apache.cassandra.utils.memory
-
- MemtableAllocator.SubAllocator - Class in org.apache.cassandra.utils.memory
-
Mark the BB as unused, permitting it to be reclaimed
- MemtableBufferAllocator - Class in org.apache.cassandra.utils.memory
-
- MemtableBufferAllocator(MemtableAllocator.SubAllocator, MemtableAllocator.SubAllocator) - Constructor for class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- memtableCellCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- MemtableCleaner - Interface in org.apache.cassandra.utils.memory
-
The cleaner is used by
MemtableCleanerThread
in order to reclaim space from memtables, normally
by flushing the largest memtable.
- MemtableCleanerThread<P extends MemtablePool> - Class in org.apache.cassandra.utils.memory
-
A thread that reclaims memory from a MemtablePool on demand.
- MemtableCleanerThread(P, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.MemtableCleanerThread
-
- MemtableCleanerThread.Clean<P extends MemtablePool> - Class in org.apache.cassandra.utils.memory
-
- memtableColumnsCount - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Total number of columns present in the memtable.
- memtableColumnsCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total number of columns present in the memtable.
- memtableDataSize - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- MemtableDiscardedNotification - Class in org.apache.cassandra.notifications
-
- MemtableDiscardedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableDiscardedNotification
-
- memtableFlushPeriod(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- memtableFlushPeriodInMs(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- memtableFlushPeriodInMs - Variable in class org.apache.cassandra.schema.TableParams
-
- memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Total amount of live data stored in the memtable, excluding any data structure overhead
- memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total amount of live data stored in the memtable, excluding any data structure overhead
- memtableOffHeapDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Total amount of data stored in the memtable that resides off-heap, including column related overhead and partitions overwritten.
- memtableOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- memtableOffHeapSize - 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.
- 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.
- memtableOnHeapSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total amount of data stored in the memtable that resides on-heap, including column related overhead and partitions overwritten.
- MemtablePool - Class in org.apache.cassandra.utils.memory
-
Represents an amount of memory used for a given purpose, that can be allocated to specific tasks through
child MemtableAllocator objects.
- MemtablePool.SubPool - Class in org.apache.cassandra.utils.memory
-
Note the difference between acquire() and allocate(); allocate() makes more resources available to all owners,
and acquire() makes shared resources unavailable but still recorded.
- MemtableRenewedNotification - Class in org.apache.cassandra.notifications
-
- MemtableRenewedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableRenewedNotification
-
- memtables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- memtableSwitchCount - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Number of times flush has resulted in the memtable being switched out.
- memtableSwitchCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Number of times flush has resulted in the memtable being switched out.
- memtableSwitchCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- MemtableSwitchedNotification - Class in org.apache.cassandra.notifications
-
- MemtableSwitchedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableSwitchedNotification
-
- MemtableUnfilteredPartitionIterator(ColumnFamilyStore, Iterator<Map.Entry<PartitionPosition, AtomicBTreePartition>>, boolean, int, ColumnFilter, DataRange) - Constructor for class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
-
- merge(TermSlice) - Method in class org.apache.cassandra.cql3.restrictions.TermSlice
-
Merges this slice with the specified one.
- merge(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Return a context w/ an aggregated count for each counter id.
- merge(List<Mutation>) - Static method in class org.apache.cassandra.db.Mutation
-
Creates a new mutation that merges all the provided mutations.
- merge(List<PartitionUpdate>) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Merges the provided updates, yielding a new update that incorporates all those updates.
- merge(List<? extends UnfilteredPartitionIterator>, int, UnfilteredPartitionIterators.MergeListener) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
-
- merge(List<V>, F) - Static method in class org.apache.cassandra.db.rows.EncodingStats
-
Merge one or more EncodingStats, that are lazily materialized from some list of arbitrary type by the provided function
- merge() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- merge(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Merger
-
- merge(Row, Row, int) - Static method in class org.apache.cassandra.db.rows.Rows
-
- merge(Row, Row, Row.Builder, int) - Static method in class org.apache.cassandra.db.rows.Rows
-
Merges two rows into the given builder, mainly for merging memtable rows.
- merge(List<UnfilteredRowIterator>, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that is the result of merging other iterators.
- merge(List<UnfilteredRowIterator>, int, UnfilteredRowIterators.MergeListener) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that is the result of merging other iterators, and (optionally) using
specific MergeListener.
- merge(CombinedValue<Long>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
-
- merge(CombinedValue<OnDiskIndex.DataTerm>) - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
-
- merge(CombinedValue<V>) - Method in interface org.apache.cassandra.index.sasi.utils.CombinedValue
-
- merge(Object[], Object[], Comparator<? super K>, UpdateFunction<K, K>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- merge(StreamingHistogram) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramBuilder
-
Merges given histogram with this histogram.
- merge(T, T) - Static method in class org.apache.cassandra.utils.Throwables
-
- mergeCounterValues(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.Conflicts
-
- mergedClustering() - Method in class org.apache.cassandra.db.rows.Row.Merger
-
- mergedMarkers() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- mergedRows() - Method in class org.apache.cassandra.db.rows.Row.Merger
-
- MergeIterator<In,Out> - Class in org.apache.cassandra.utils
-
Merges sorted input iterators which individually contain unique items.
- MergeIterator(List<? extends Iterator<In>>, MergeIterator.Reducer<In, Out>) - Constructor for class org.apache.cassandra.utils.MergeIterator
-
- MergeIterator.Candidate<In> - Class in org.apache.cassandra.utils
-
- MergeIterator.Reducer<In,Out> - Class in org.apache.cassandra.utils
-
Accumulator that collects values of type A, and outputs a value of type B.
- mergeLazily(List<? extends UnfilteredPartitionIterator>, int) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
-
- Merger(int, DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
-
- Merger(int, int, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Merger
-
- mergeSchema(Collection<Mutation>) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- mergeSchemaAndAnnounceVersion(Collection<Mutation>) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
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)
- mergeSchemaFrom(InetAddress, Collection<Mutation>) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- mergeTo(Columns) - Method in class org.apache.cassandra.db.Columns
-
Returns the result of merging this Columns
object with the
provided one.
- mergeTo(PartitionColumns) - Method in class org.apache.cassandra.db.PartitionColumns
-
- mergeTombstoneHistogram(StreamingHistogram) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- mergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- mergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- mergeWith(SingleRestriction) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
-
Merges this restriction with the specified one.
- mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- mergeWith(EncodingStats) - Method in class org.apache.cassandra.db.rows.EncodingStats
-
Merge this stats with another one.
- MerkleTree - Class in org.apache.cassandra.utils
-
A MerkleTree implemented as a binary tree.
- MerkleTree(IPartitioner, Range<Token>, byte, long) - Constructor for class org.apache.cassandra.utils.MerkleTree
-
- MerkleTree.MerkleTreeSerializer - Class in org.apache.cassandra.utils
-
- MerkleTree.RowHash - Class in org.apache.cassandra.utils
-
Hash value representing a row, to be used to pass hashes to the MerkleTree.
- MerkleTree.TreeDifference - Class in org.apache.cassandra.utils
-
- MerkleTree.TreeRange - Class in org.apache.cassandra.utils
-
The public interface to a range in the tree.
- MerkleTree.TreeRangeIterator - Class in org.apache.cassandra.utils
-
Returns the leaf (range) of a given tree in increasing order.
- 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
-
- MerkleTreeSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- MerkleTreesSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
-
- Message - Class in org.apache.cassandra.transport
-
A message from the CQL binary protocol.
- Message(Message.Type) - Constructor for class org.apache.cassandra.transport.Message
-
- Message.Codec<M extends Message> - Interface in org.apache.cassandra.transport
-
- Message.Direction - Enum in org.apache.cassandra.transport
-
- Message.Dispatcher - Class in org.apache.cassandra.transport
-
- Message.ExceptionHandler - Class in org.apache.cassandra.transport
-
- Message.ProtocolDecoder - Class in org.apache.cassandra.transport
-
- Message.ProtocolEncoder - Class in org.apache.cassandra.transport
-
- Message.Request - Class in org.apache.cassandra.transport
-
- Message.Response - Class in org.apache.cassandra.transport
-
- Message.Type - Enum in org.apache.cassandra.transport
-
- MessageDeliveryTask - Class in org.apache.cassandra.net
-
- MessageDeliveryTask(MessageIn<?>, int) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
-
- MessageIn<T> - Class in org.apache.cassandra.net
-
- MessageOut<T> - Class in org.apache.cassandra.net
-
- MessageOut(MessagingService.Verb) - Constructor for class org.apache.cassandra.net.MessageOut
-
- MessageOut(MessagingService.Verb, T, IVersionedSerializer<T>) - Constructor for class org.apache.cassandra.net.MessageOut
-
- MessageOut(InetAddress, MessagingService.Verb, T, IVersionedSerializer<T>, Map<String, byte[]>) - Constructor for class org.apache.cassandra.net.MessageOut
-
- messageReceived(StreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
- messageType - Variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- MessagingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for messages
- MessagingMetrics() - Constructor for class org.apache.cassandra.metrics.MessagingMetrics
-
- MessagingService - Class in org.apache.cassandra.net
-
- MessagingService.SocketThread - Class in org.apache.cassandra.net
-
- MessagingService.Verb - Enum in org.apache.cassandra.net
-
- MessagingServiceMBean - Interface in org.apache.cassandra.net
-
MBean exposing MessagingService metrics plus allowing to enable/disable back-pressure.
- metadata() - Static method in class org.apache.cassandra.auth.AuthKeyspace
-
- metadata - Variable in class org.apache.cassandra.config.ViewDefinition
-
- metadata - Variable in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- metadata - Variable in class org.apache.cassandra.cql3.ResultSet
-
- metadata() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- metadata - Variable in class org.apache.cassandra.cql3.UpdateParameters
-
- metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- metadata() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- metadata() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- metadata - Variable in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
- metadata() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
-
- metadata - Variable in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- metadata() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- metadata() - Method in interface org.apache.cassandra.db.partitions.Partition
-
- 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.ReadCommand
-
The metadata for the table queried.
- metaData() - Method in class org.apache.cassandra.db.ReadExecutionController
-
- metadata - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- metadata() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- metadata() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
-
The metadata for the table this iterator on.
- metadata() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- metadata() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
-
- metadata() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- metadata() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
-
- metadata() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- metadata() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- metadata() - Method in class org.apache.cassandra.db.transform.BaseRows
-
- metadata - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
-
- metadata - Variable in class org.apache.cassandra.index.internal.CassandraIndex
-
- metadata() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- metadata() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- metadata() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- metadata() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- metadata - Variable in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
-
- metadata() - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- metadata() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- metadata() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- metadata() - Static method in class org.apache.cassandra.tracing.TraceKeyspace
-
- metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
Describes the variables to be bound in the prepared statement
- metadataBuilder() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- metadataCollector - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- MetadataCollector - Class in org.apache.cassandra.io.sstable.metadata
-
- MetadataCollector(ClusteringComparator) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- MetadataCollector(ClusteringComparator, UUID) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- MetadataCollector(Iterable<SSTableReader>, ClusteringComparator, int) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- MetadataCollector.MinMaxIntTracker - Class in org.apache.cassandra.io.sstable.metadata
-
- MetadataCollector.MinMaxLongTracker - Class in org.apache.cassandra.io.sstable.metadata
-
- MetadataComponent - Class in org.apache.cassandra.io.sstable.metadata
-
MetadataComponent is a component for SSTable metadata and serialized to Stats.db.
- MetadataComponent() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataComponent
-
- metadataFromSSTable(Descriptor) - Static method in class org.apache.cassandra.tools.SSTableExport
-
Construct table schema from info stored in SSTable's Stats.db
- metadatas() - Method in class org.apache.cassandra.schema.Views
-
- MetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
Metadata serializer for SSTables version >= 'k'
.
- MetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- MetadataType - Enum in org.apache.cassandra.io.sstable.metadata
-
Defines Metadata component type.
- meter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- 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
-
- MetricName(String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- MetricName(Class<?>, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- MetricName(String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- MetricName(String, String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- MetricNameFactory - Interface in org.apache.cassandra.metrics
-
- metricPercentilesAsArray(CassandraMetricsRegistry.JmxHistogramMBean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- metricPercentilesAsArray(CassandraMetricsRegistry.JmxTimerMBean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- metrics - Variable in class org.apache.cassandra.cache.ChunkCache
-
- metrics - Variable in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- metrics - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- metrics - Variable in class org.apache.cassandra.hints.HintsService
-
- Metrics - Static variable in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- metrics - Variable in class org.apache.cassandra.net.MessagingService
-
- metricsFor(UUID) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- mEXPONENT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mF() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mFLOAT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mG() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mH() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mHEX() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mHEXNUMBER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mI() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- microsTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- mIDENT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate a Token representing the approximate "middle" of the given
range.
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Given two bit arrays represented as BigIntegers, containing the given
number of significant bits, calculate a midpoint.
- migrate() - Static method in class org.apache.cassandra.batchlog.LegacyBatchlogMigrator
-
- migrate() - Method in class org.apache.cassandra.hints.LegacyHintsMigrator
-
- migrate() - Static method in class org.apache.cassandra.schema.LegacySchemaMigrator
-
- migrateDataDirs() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Check data directories for old files that can be removed when migrating from 2.1 or 2.2 to 3.0,
these checks can be removed in 4.0, see CASSANDRA-7066
- MigrationCoordinator - Class in org.apache.cassandra.service
-
- MigrationCoordinator() - Constructor for class org.apache.cassandra.service.MigrationCoordinator
-
- MigrationListener - Class in org.apache.cassandra.service
-
- MigrationListener() - Constructor for class org.apache.cassandra.service.MigrationListener
-
- MigrationManager - Class in org.apache.cassandra.service
-
- MigrationManager.MigrationsSerializer - Class in org.apache.cassandra.service
-
- MigrationRequestVerbHandler - Class in org.apache.cassandra.db
-
Sends it's current schema state in form of mutations in reply to the remote node's request.
- MigrationRequestVerbHandler() - Constructor for class org.apache.cassandra.db.MigrationRequestVerbHandler
-
- MigrationsSerializer() - Constructor for class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- min - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- min - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
-
- min() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- min - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- min() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
-
- min() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
-
- min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- min - Variable in class org.apache.cassandra.utils.Interval
-
- min() - Method in class org.apache.cassandra.utils.IntervalTree
-
- MIN_BUFFER_SIZE - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
-
- MIN_BUFFER_SIZE_MASK - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
-
- min_free_space_per_drive_in_mb - Variable in class org.apache.cassandra.config.Config
-
- MIN_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- minClusteringValues - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- minCompactionThreshold() - Method in class org.apache.cassandra.schema.CompactionParams
-
- minFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The MIN function for counter column values.
- minimalBufferFor(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
trims size of bytebuffer to exactly number of bytes in it, to do not hold too much memory
- minimize() - Method in class org.apache.cassandra.db.BufferClustering
-
- minimize() - Method in class org.apache.cassandra.db.ClusteringBound
-
- minimize() - Method in class org.apache.cassandra.db.ClusteringBoundary
-
- minimize() - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
- minimize() - Method in class org.apache.cassandra.db.NativeClustering
-
- minimizeBuffers(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- minimumVersion - Variable in enum org.apache.cassandra.transport.Event.Type
-
- minIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- minIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- minIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
-
- minKey - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- minKey() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- minKey() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- minKeyBound() - Method in class org.apache.cassandra.dht.Token
-
- minLocalDeletionTime - Variable in class org.apache.cassandra.db.rows.EncodingStats
-
- minLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- MinMaxIntTracker() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
-
- MinMaxIntTracker(int, int) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
-
- MinMaxLongTracker() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
-
- MinMaxLongTracker(long, long) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
-
- minOffset(OnDiskIndex.IteratorOrder) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- minor - Variable in class org.apache.cassandra.utils.CassandraVersion
-
- minOrdering() - Static method in class org.apache.cassandra.utils.Interval
-
- minPartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Size of the smallest compacted partition
- minRange - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- minRepairedAt - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- minRight(AbstractBounds.Boundary<T>, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- minRight(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- minSupportedBloomFilterFpChance() - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Retrieves the minimum supported BloomFilterFpChance value
- mINTEGER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- minTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- minTerm() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- minTerm() - Method in class org.apache.cassandra.index.sasi.sa.TermIterator
-
- minTerm() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- minTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
-
- minTimestamp - Variable in class org.apache.cassandra.db.rows.EncodingStats
-
- minTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- minTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns the smaller possible type 1 UUID having the provided timestamp.
- minTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
- minTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
Set the min allowed token length.
- minTTL - Variable in class org.apache.cassandra.db.rows.EncodingStats
-
- minTTL - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- minValue() - Method in class org.apache.cassandra.db.DecoratedKey
-
- minValue() - Method in interface org.apache.cassandra.dht.RingPosition
-
- minValue() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- minValue() - Method in class org.apache.cassandra.dht.Token
-
- misses - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
-
Total number of misses
- misses - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
Total number of cache hits
- missLatency - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
Latency of misses
- mJ() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ADD() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_AGGREGATE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ALL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ALLOW() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ALTER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_AND() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_APPLY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_AS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ASC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ASCII() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_AUTHORIZE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BATCH() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BEGIN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BIGINT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BLOB() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BOOLEAN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_BY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CALLED() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CAST() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CLUSTERING() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_COMPACT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CONTAINS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_COUNT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_COUNTER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CREATE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_CUSTOM() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DATE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DECIMAL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DEFAULT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DELETE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DESC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DESCRIBE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DISTINCT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DOUBLE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DROP() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_DURATION() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ENTRIES() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_EXECUTE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_EXISTS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FILTERING() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FINALFUNC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FLOAT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FROM() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FROZEN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FULL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FUNCTION() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_FUNCTIONS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_GRANT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_GROUP() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_IF() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_IN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INDEX() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INET() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INFINITY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INITCOND() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INPUT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INSERT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_INTO() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_IS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_JSON() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_KEY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_KEYS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_KEYSPACE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_KEYSPACES() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_LANGUAGE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_LIKE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_LIMIT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_LIST() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_LOGIN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_MAP() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_MATERIALIZED() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_MBEAN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_MBEANS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_MODIFY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NAN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NOLOGIN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NORECURSIVE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NOSUPERUSER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NOT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_NULL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_OF() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ON() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_OPTIONS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_OR() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ORDER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PARTITION() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PASSWORD() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PERMISSION() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PERMISSIONS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_PRIMARY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_RENAME() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_REPLACE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_RETURNS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_REVOKE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ROLE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_ROLES() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_SELECT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_SET() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_SFUNC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_SMALLINT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_STATIC() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_STORAGE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_STYPE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_SUPERUSER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TEXT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TIME() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TIMESTAMP() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TIMEUUID() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TINYINT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TO() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TOKEN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TRIGGER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TRUNCATE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TTL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TUPLE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_TYPE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_UNLOGGED() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_UNSET() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_UPDATE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_USE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_USER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_USERS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_USING() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_UUID() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_VALUES() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_VARCHAR() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_VARINT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_VIEW() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_WHERE() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_WITH() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mK_WRITETIME() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mLETTER() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mM() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- Mmap(ChannelProxy, CompressionMetadata, MmappedRegions) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
-
- mmapped(boolean) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Set whether to use mmap for reading
- MmappedRegions - Class in org.apache.cassandra.io.util
-
- MmappedRegions.Region - Class in org.apache.cassandra.io.util
-
- MmappedRegions.Tidier - Class in org.apache.cassandra.io.util
-
- mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mN() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mO() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mockKS(KeyspaceMetadata) - Static method in class org.apache.cassandra.db.Keyspace
-
- mode - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- mode - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
-
- mode - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- mode() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- mode(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
-
- mode - Variable in class org.apache.cassandra.index.sasi.sa.SA
-
- mode() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- ModificationStatement - Class in org.apache.cassandra.cql3.statements
-
- ModificationStatement(StatementType, int, CFMetaData, Operations, StatementRestrictions, Conditions, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
-
- ModificationStatement.Parsed - Class in org.apache.cassandra.cql3.statements
-
- Monitorable - Interface in org.apache.cassandra.db.monitoring
-
- MonitorableImpl - Class in org.apache.cassandra.db.monitoring
-
- MonitorableImpl() - Constructor for class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- monitorEnterUnsafe(Object) - Static method in class org.apache.cassandra.utils.concurrent.Locks
-
- monitorExitUnsafe(Object) - Static method in class org.apache.cassandra.utils.concurrent.Locks
-
- MonitoringState - Enum in org.apache.cassandra.db.monitoring
-
- MONTHS_PER_YEAR - Static variable in class org.apache.cassandra.cql3.Duration
-
- MorePartitions<I extends BasePartitionIterator<?>> - Interface in org.apache.cassandra.db.transform
-
An interface for providing new partitions for a partitions iterator.
- MoreRows<I extends BaseRowIterator<?>> - Interface in org.apache.cassandra.db.transform
-
An interface for providing new row contents for a partition.
- mostInterestingBucket(List<List<SSTableReader>>, int, int) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- mostRecentInProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- move(String) - Method in class org.apache.cassandra.service.StorageService
-
- move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- move(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Move - Class in org.apache.cassandra.tools.nodetool
-
- Move() - Constructor for class org.apache.cassandra.tools.nodetool.Move
-
- movedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
-
- moveToNext() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- moving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- mP() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mQ() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mQMARK() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mQUOTED_NAME() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mR() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- mSTRING_LITERAL() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mT() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mT__186() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__187() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__188() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__189() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__190() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__191() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__192() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__193() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__194() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__195() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__196() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__197() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__198() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__199() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__200() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__201() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__202() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__203() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__204() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__205() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__206() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__207() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mTokens() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mTokens() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mU() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- MultiCBuilder - Class in org.apache.cassandra.db
-
Builder that allow to build multiple Clustering/ClusteringBound at the same time.
- MultiCBuilder(ClusteringComparator) - Constructor for class org.apache.cassandra.db.MultiCBuilder
-
- MultiColumnRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
-
- MultiColumnRaw() - Constructor for class org.apache.cassandra.cql3.Term.MultiColumnRaw
-
- MultiColumnRelation - Class in org.apache.cassandra.cql3
-
A relation using the tuple notation, which typically affects multiple columns.
- MultiColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- MultiColumnRestriction(List<ColumnDefinition>) - 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
-
- multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- MultiItemTerminal() - Constructor for class org.apache.cassandra.cql3.Term.MultiItemTerminal
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- MultiPartitionPager - Class in org.apache.cassandra.service.pager
-
Pager over a list of ReadCommand.
- MultiPartitionPager(SinglePartitionReadCommand.Group, PagingState, ProtocolVersion) - Constructor for class org.apache.cassandra.service.pager.MultiPartitionPager
-
- MULTIPLE_EXPRESSIONS - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
- Murmur3Partitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using a Murmur3 hash.
- Murmur3Partitioner() - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner
-
- Murmur3Partitioner.LongToken - Class in org.apache.cassandra.dht
-
- MurmurHash - Class in org.apache.cassandra.utils
-
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
- MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
-
- mutableCopy() - Method in interface org.apache.cassandra.db.DeletionInfo
-
- mutableCopy() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- MutableDeletionInfo - Class in org.apache.cassandra.db
-
A mutable implementation of DeletionInfo
.
- MutableDeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
-
Creates a DeletionInfo with only a top-level (row) tombstone.
- MutableDeletionInfo(DeletionTime) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
-
- MutableDeletionInfo(DeletionTime, RangeTombstoneList) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
-
- MutableDeletionInfo.Builder - Class in org.apache.cassandra.db
-
Builds DeletionInfo object from (in order) range tombstone markers.
- mutate(Collection<? extends IMutation>, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied
across all replicas.
- mutateAtomically(Collection<Mutation>, ConsistencyLevel, boolean, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
See mutate.
- mutateCounter(CounterMutation, String, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
Handle counter mutation on the coordinator host.
- mutateLevel(Descriptor, int) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Mutate SSTable level
- mutateLevel(Descriptor, int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- mutateLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- mutateMV(ByteBuffer, Collection<Mutation>, boolean, AtomicLong, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied
across all replicas.
- mutateRepairedAt(Descriptor, long) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Mutate repairedAt time
- mutateRepairedAt(Descriptor, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- mutateRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- mutateWithTriggers(Collection<? extends IMutation>, ConsistencyLevel, boolean, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- Mutation - Class in org.apache.cassandra.db
-
- Mutation(String, DecoratedKey) - Constructor for class org.apache.cassandra.db.Mutation
-
- Mutation(String, DecoratedKey, long, boolean) - Constructor for class org.apache.cassandra.db.Mutation
-
- Mutation(PartitionUpdate) - Constructor for class org.apache.cassandra.db.Mutation
-
- Mutation(String, DecoratedKey, Map<UUID, PartitionUpdate>) - Constructor for class org.apache.cassandra.db.Mutation
-
- mutation() - Method in class org.apache.cassandra.net.WriteCallbackInfo
-
- Mutation.MutationSerializer - Class in org.apache.cassandra.db
-
- 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
-
- 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
-
- 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
-
- mUUID() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mV() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mW() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mWS() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mX() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- Mx4jTool - Class in org.apache.cassandra.utils
-
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
- Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
-
- mY() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- mZ() - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- R - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- R - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- R - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
-
- RackInferringSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded
in the 2nd and 3rd octets of the ip address, respectively.
- RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
-
- RandomAccessReader - Class in org.apache.cassandra.io.util
-
- RandomPartitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using MD5 hash.
- RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
-
- RandomPartitioner.BigIntegerToken - Class in org.apache.cassandra.dht
-
- Range<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
-
A representation of the range that a node is responsible for on the DHT ring.
- Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
-
- range - Variable in class org.apache.cassandra.index.sasi.plan.Operation
-
- range - Variable in class org.apache.cassandra.service.StorageProxy.RangeForQuery
-
- Range.OrderedRangeContainmentChecker - Class in org.apache.cassandra.dht
-
Helper class to check if a token is contained within a given collection of ranges
- range_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RANGE_XFERS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- RangeAwareSSTableWriter - Class in org.apache.cassandra.io.sstable.format
-
- RangeAwareSSTableWriter(ColumnFamilyStore, long, long, SSTableFormat.Type, int, long, LifecycleNewTracker, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- RangeCommandIterator(Iterator<StorageProxy.RangeForQuery>, PartitionRangeReadCommand, int, int, int, Keyspace, ConsistencyLevel, long) - Constructor for class org.apache.cassandra.service.StorageProxy.RangeCommandIterator
-
- rangeCount() - Method in interface org.apache.cassandra.db.DeletionInfo
-
- rangeCount() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- rangeCount() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- rangeCount() - Method in class org.apache.cassandra.service.StorageProxy.RangeIterator
-
- rangeCovering(Clustering) - Method in interface org.apache.cassandra.db.DeletionInfo
-
- rangeCovering(Clustering) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- RangeForQuery(AbstractBounds<PartitionPosition>, List<InetAddress>, List<InetAddress>, int) - Constructor for class org.apache.cassandra.service.StorageProxy.RangeForQuery
-
- RangeIntersectionIterator - Class in org.apache.cassandra.index.sasi.utils
-
- RangeIntersectionIterator() - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
-
- RangeIntersectionIterator.BounceIntersectionIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
-
Iterator which performs intersection of multiple ranges by using bouncing (merge-join) technique to identify
common elements in the given ranges.
- RangeIntersectionIterator.Builder<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
-
- RangeIntersectionIterator.LookupIntersectionIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
-
Iterator which performs a linear scan over a primary range (the smallest of the ranges)
and O(log(n)) lookup into secondary ranges using values from the primary iterator.
- RangeIntersectionIterator.Strategy - Enum in org.apache.cassandra.index.sasi.utils
-
- rangeIterator(boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
-
- rangeIterator(Slice, boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
-
- rangeIterator(boolean) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- rangeIterator(Slice, boolean) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- RangeIterator<K extends java.lang.Comparable<K>,T extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
-
- RangeIterator(RangeIterator.Builder.Statistics<K, T>) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- RangeIterator(RangeIterator<K, T>) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- RangeIterator(K, K, long) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- RangeIterator(PartitionRangeReadCommand, Keyspace, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.StorageProxy.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
-
- 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
- RangeMerger(Iterator<StorageProxy.RangeForQuery>, Keyspace, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.StorageProxy.RangeMerger
-
- ranges - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- 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.RepairSession
-
Range to repair
- ranges - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- ranges() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get the ranges that these merkle trees covers.
- RANGES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSliceSerializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- rangeSliceSerializer - Static variable in class org.apache.cassandra.db.ReadResponse
-
- RangeSliceVerbHandler - Class in org.apache.cassandra.db
-
- RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.db.RangeSliceVerbHandler
-
- rangesQueried() - Method in class org.apache.cassandra.service.StorageProxy.RangeCommandIterator
-
- RangeStreamer - Class in org.apache.cassandra.dht
-
Assists in streaming ranges to a node.
- RangeStreamer(TokenMetadata, Collection<Token>, InetAddress, String, boolean, IEndpointSnitch, StreamStateStore, boolean) - Constructor for class org.apache.cassandra.dht.RangeStreamer
-
- RangeStreamer.AllowedSourcesFilter - Class in org.apache.cassandra.dht
-
Source filter which only includes endpoints contained within a provided set.
- RangeStreamer.ExcludeLocalNodeFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes the current node from source calculations
- RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not alive according to a
failure detector.
- RangeStreamer.ISourceFilter - Interface in org.apache.cassandra.dht
-
A filter applied to sources to stream from when constructing a fetch map.
- RangeStreamer.SingleDatacenterFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not in a specific data center.
- RangeTermTree - Class in org.apache.cassandra.index.sasi.conf.view
-
- RangeTermTree(ByteBuffer, ByteBuffer, IntervalTree<RangeTermTree.Term, SSTableIndex, Interval<RangeTermTree.Term, SSTableIndex>>, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- RangeTermTree.Term - Class in org.apache.cassandra.index.sasi.conf.view
-
This is required since IntervalTree doesn't support custom Comparator
implementations and relied on items to be comparable which "raw" terms are not.
- RangeTombstone - Class in org.apache.cassandra.db
-
A range tombstone is a tombstone that covers a slice/range of rows.
- RangeTombstone(Slice, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- rangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.index.Index.Indexer
-
Notification of a RangeTombstone.
- RangeTombstoneBoundaryMarker - Class in org.apache.cassandra.db.rows
-
A range tombstone marker that represents a boundary between 2 range tombstones (i.e.
- RangeTombstoneBoundaryMarker(ClusteringBoundary, DeletionTime, DeletionTime) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- RangeTombstoneBoundMarker - Class in org.apache.cassandra.db.rows
-
A range tombstone marker that indicates the bound of a range tombstone (start or end).
- RangeTombstoneBoundMarker(ClusteringBound, DeletionTime) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- RangeTombstoneList - Class in org.apache.cassandra.db
-
Data structure holding the range tombstones of a ColumnFamily.
- RangeTombstoneList(ClusteringComparator, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
-
- RangeTombstoneMarker - Interface in org.apache.cassandra.db.rows
-
A marker for a range tombstone bound.
- RangeTombstoneMarker.Merger - Class in org.apache.cassandra.db.rows
-
Utility class to help merging range tombstone markers coming from multiple inputs (UnfilteredRowIterators).
- rangeTombstones - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyUnfilteredPartition
-
- 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
-
- RateBasedBackPressure - Class in org.apache.cassandra.net
-
Back-pressure algorithm based on rate limiting according to the ratio between incoming and outgoing rates, computed
over a sliding time window with size equal to write RPC timeout.
- RateBasedBackPressure(Map<String, Object>) - Constructor for class org.apache.cassandra.net.RateBasedBackPressure
-
- RateBasedBackPressure(Map<String, Object>, TimeSource, long) - Constructor for class org.apache.cassandra.net.RateBasedBackPressure
-
- Raw() - Constructor for class org.apache.cassandra.config.ColumnDefinition.Raw
-
- Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.CQL3Type.Raw
-
- Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.selection.Selectable.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(FunctionName, List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
-
- Raw(Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTerm.Raw
-
- Raw(ColumnDefinition.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.Term.Raw
-
- Raw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.Raw
-
- rawAddRow(ByteBuffer...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawAddRow(List<ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawAddRow(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawBuilder(String) - Static method in class org.apache.cassandra.schema.Types
-
- rawCQLStatement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- rawMean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- RawSelector - Class in org.apache.cassandra.cql3.selection
-
- RawSelector(Selectable.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.RawSelector
-
- RawStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- RawStatement(CFName, SelectStatement.Parameters, List<RawSelector>, WhereClause, Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- rawText() - Method in class org.apache.cassandra.config.ColumnDefinition.Raw
-
- read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- read(byte[], int, int) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- read(ByteBuffer, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- read() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads a single byte from the source byte array and returns it as an
integer in the range from 0 to 255.
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads at most len
bytes from this stream and stores
them in byte array b
starting at offset
.
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- read() - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
- read(DataInputPlus, int, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- read(DataInputPlus, int, int, long) - Static method in class org.apache.cassandra.net.MessageIn
-
- read(ByteBuffer) - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- read(SinglePartitionReadCommand.Group, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- read(SinglePartitionReadCommand.Group, ConsistencyLevel, ClientState, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
- read() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.StreamReader
-
- read(List<SinglePartitionReadCommand>, ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- read_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- READABLE_SYSTEM_RESOURCES - Static variable in class org.apache.cassandra.service.ClientState
-
- ReadableBoundary(DecoratedKey, long, long, int, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- readAllFiles(CommitLogReadHandler, File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
-
Reads all passed in files with no minimum, no start, and no mutation limit.
- readAllFiles(CommitLogReadHandler, File[], CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
-
Reads all passed in files with minPosition, no start, and no mutation limit.
- readBoolean() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readBoolean() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readBoolean() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readBoundValue(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBuffer() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- readBuffer() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
- readBuffer() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
-
- readByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readByte() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readByte() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readBytesMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytesWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadCallback - Class in org.apache.cassandra.service
-
- ReadCallback(ResponseResolver, ConsistencyLevel, ReadCommand, List<InetAddress>, long) - Constructor for class org.apache.cassandra.service.ReadCallback
-
Constructor when response count has to be calculated and blocked for.
- ReadCallback(ResponseResolver, ConsistencyLevel, int, ReadCommand, Keyspace, List<InetAddress>, long) - Constructor for class org.apache.cassandra.service.ReadCallback
-
- readChar() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readChar() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readChar() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readChunk(long, ByteBuffer) - Method in interface org.apache.cassandra.io.util.ChunkReader
-
Read the chunk at the given position, attempting to fill the capacity of the given buffer.
- readChunk(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
-
- readChunk(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Standard
-
- readCollectionSize(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- readCommand(int) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- ReadCommand - Class in org.apache.cassandra.db
-
General interface for storage-engine read commands (common to both range and
single partition commands).
- ReadCommand(ReadCommand.Kind, boolean, int, boolean, CFMetaData, int, ColumnFilter, RowFilter, DataLimits, IndexMetadata) - Constructor for class org.apache.cassandra.db.ReadCommand
-
- readCommand(int) - Method in interface org.apache.cassandra.service.CASRequest
-
The command to use to fetch the value to compare for the CAS.
- ReadCommand.CheckForAbort - Class in org.apache.cassandra.db
-
- ReadCommand.Kind - Enum in org.apache.cassandra.db
-
- ReadCommand.SelectionDeserializer - Class in org.apache.cassandra.db
-
- 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, 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
-
- readConstructionTime(InetAddress, DataInputPlus, long) - Static method in class org.apache.cassandra.net.MessageIn
-
- readCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
-
- readDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- readDouble() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readDouble() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readDouble() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readEnumValue(Class<T>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- reader - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- Reader(FileDataInput, boolean) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- 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
-
- readException - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- ReadExecutionController - Class in org.apache.cassandra.db
-
- readExtendedFlags(DataInputPlus, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- ReadFailureException - Exception in org.apache.cassandra.exceptions
-
- ReadFailureException(ConsistencyLevel, int, int, boolean, Map<InetAddress, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
-
- readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- readFloat() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readFloat() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readFloat() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readFrom(DataInput) - Static method in enum org.apache.cassandra.cql3.Operator
-
Deserializes a Operator
instance from the specified input.
- readFully(byte[]) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readHeader(DataInput, EncryptionContext) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- readInet(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readInetAddr(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readInt() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readInt() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- readLatency - Variable in class org.apache.cassandra.metrics.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
-
- readLegacyAtom(CFMetaData, DataInputPlus, boolean) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- readLegacyCell(CFMetaData, DataInput, SerializationHelper.Flag) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- readLegacyCellBody(CFMetaData, DataInput, ByteBuffer, int, SerializationHelper.Flag, boolean) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- readLegacyRangeTombstoneBody(CFMetaData, DataInputPlus, ByteBuffer) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- readLine() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
Reads a line of text form the current position in this file.
- readLine() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readLine() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readLine() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readLines(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- readLocalDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- readLong() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readLong() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readLong() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readMutation(CommitLogReadHandler, byte[], int, CommitLogPosition, int, CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
-
Deserializes and passes a Mutation to the ICommitLogReadHandler requested
- readNameAndValueList(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer.OldFormatDeserializer
-
- readNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Returns the next atom.
- readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readOne(SinglePartitionReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- readOne(SinglePartitionReadCommand, ConsistencyLevel, ClientState, long) - Static method in class org.apache.cassandra.service.StorageProxy
-
- readOrdering - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- readPosition(DataInputPlus, Version) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
Reads only the data 'position' of the index entry and returns it.
- readPrimitiveSlowly(int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- ReadQuery - Interface in org.apache.cassandra.db
-
Generic abstraction for read queries.
- readRawBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- readRepairChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- readRepairChance - Variable in class org.apache.cassandra.schema.TableParams
-
- ReadRepairDecision - Enum in org.apache.cassandra.config
-
- ReadRepairMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Read Repair.
- ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
-
- readRepairRequests - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- ReadRepairVerbHandler - Class in org.apache.cassandra.db
-
- ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
-
- ReadResponse - Class in org.apache.cassandra.db
-
- ReadResponse(ReadCommand) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- readSerializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- readShort() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readShort() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readShort() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readStaticRow() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
-
- readString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringList(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringToStringListMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadTimeoutException - Exception in org.apache.cassandra.exceptions
-
- ReadTimeoutException(ConsistencyLevel, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- readTimestamp(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Reads the list of components from the TOC component.
- readTTL(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readUnsignedVInt() - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
Think hard before opting for an unsigned encoding.
- readUnsignedVInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readUnsignedVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
- readUTF() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readUTF() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- readUTF() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- readUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- readValue(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- readValue(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- readValue(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- readValue(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- readValue(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ByteBuf, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
-
- readValueList(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readVInt() - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
- readVInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- readVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
- readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readWithVIntLength(DataInputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadyMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- ReadyMessage() - Constructor for class org.apache.cassandra.transport.messages.ReadyMessage
-
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
-
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
-
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
-
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- realMarkAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- reason - Variable in exception org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadException
-
- rebind(String, Remote) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
-
- reBuffer() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
-
- reBuffer() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- rebuffer(long) - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- reBuffer() - Method in class org.apache.cassandra.io.util.DataInputBuffer
-
- rebuffer(long) - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- reBuffer() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- reBuffer() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
Read data from file starting from current currentOffset to populate buffer.
- rebuffer(long) - Method in interface org.apache.cassandra.io.util.Rebufferer
-
Rebuffer (move on or seek to) a given position, and return a buffer that can be used there.
- reBuffer() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
Implementations must implement this method to refill the buffer.
- Rebufferer - Interface in org.apache.cassandra.io.util
-
Rebufferer for reading data by a RandomAccessReader.
- Rebufferer.BufferHolder - Interface in org.apache.cassandra.io.util
-
- rebuffererFactory() - Method in class org.apache.cassandra.io.util.FileHandle
-
- RebuffererFactory - Interface in org.apache.cassandra.io.util
-
Interface for the classes that can be used to instantiate rebufferers over a given file.
- RebufferingInputStream - Class in org.apache.cassandra.io.util
-
Rough equivalent of BufferedInputStream and DataInputStream wrapping a ByteBuffer that can be refilled
via rebuffer.
- RebufferingInputStream(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.RebufferingInputStream
-
- rebuild(String) - Method in class org.apache.cassandra.service.StorageService
-
- rebuild(String, String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
- rebuild(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Initiate a process of streaming data for which we are responsible from other nodes.
- rebuild(String, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- rebuild(String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Rebuild - Class in org.apache.cassandra.tools.nodetool
-
- Rebuild() - Constructor for class org.apache.cassandra.tools.nodetool.Rebuild
-
- rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RebuildIndex - Class in org.apache.cassandra.tools.nodetool
-
- RebuildIndex() - Constructor for class org.apache.cassandra.tools.nodetool.RebuildIndex
-
- rebuildIndexesBlocking(Collection<SSTableReader>, Set<String>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Does a full, blocking rebuild of the indexes specified by columns from the sstables.
- rebuildLWTColumnConditions(Conditions, CFMetaData, WhereClause) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
Rebuilds LWT conditions on SuperColumn _value_ column.
- 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
- recalculateIsDense(Columns) - Static method in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
Dense flag might have been incorrectly set if the node was upgraded from 2.x before CASSANDRA-12373.
- receive(MessageIn, int) - Method in class org.apache.cassandra.net.MessagingService
-
- receive(IncomingFileMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after receiving FileMessageHeader.
- received - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
-
- received(SSTableMultiWriter) - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
Process received file.
- received(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
- ReceivedMessage - Class in org.apache.cassandra.streaming.messages
-
- ReceivedMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
-
- receivers(CFMetaData) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
-
- receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of receiving summaries
- recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Number of false positives in bloom filter from last read
- recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.TableMetrics
-
False positive ratio of bloom filter from last read
- 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.OldNetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- 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
-
- RecomputingSupplier(Supplier<T>, ExecutorService) - Constructor for class org.apache.cassandra.utils.RecomputingSupplier
-
- reconcile(Cell, Cell, DeletionTime, Row.Builder, int) - Static method in class org.apache.cassandra.db.rows.Cells
-
Reconciles/merges two cells, one being an update to an existing cell,
yielding index updates if appropriate.
- reconcile(Cell, Cell, int) - Static method in class org.apache.cassandra.db.rows.Cells
-
Reconciles/merge two cells.
- reconcileComplex(ColumnDefinition, Iterator<Cell>, Iterator<Cell>, DeletionTime, Row.Builder, int) - Static method in class org.apache.cassandra.db.rows.Cells
-
Computes the reconciliation of a complex column given its pre-existing
cells and the ones it is updated with, and generating index update if
appropriate.
- ReconnectableSnitchHelper - Class in org.apache.cassandra.locator
-
Sidekick helper for snitches that want to reconnect from one IP addr for a node to another.
- ReconnectableSnitchHelper(IEndpointSnitch, String, boolean) - Constructor for class org.apache.cassandra.locator.ReconnectableSnitchHelper
-
- recordColumnDrop(ColumnDefinition, long) - Method in class org.apache.cassandra.config.CFMetaData
-
Adds the column definition as a dropped column, recording the drop with the provided timestamp.
- recordColumnDrop(ColumnDefinition, long, boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- recover(IntStream, RecognitionException) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- recover(IntStream, RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
-
- recover(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a single commit log.
- recover(String) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Recover a single file.
- recoverFiles(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a list of commit log files.
- recoverFromMismatchedToken(IntStream, int, BitSet) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- recoverFromMismatchedToken(IntStream, int, BitSet) - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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.
- recursive - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- recvBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- redistributeSummaries(IndexSummaryRedistribution) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on
their recent read rates.
- redistributeSummaries() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- reduce(int, In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
combine this object with the previous ones.
- reducer - Variable in class org.apache.cassandra.utils.MergeIterator
-
- Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
-
- reduceScopeForLimitedSpace(long) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- reduceScopeForLimitedSpace(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 - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- Ref<T> - Class in org.apache.cassandra.utils.concurrent
-
An object that needs ref counting does the two following:
- defines a Tidy object that will cleanup once it's gone,
(this must retain no references to the object we're tracking (only its resources and how to clean up))
Then, one of two options:
1) Construct a Ref directly pointing to it, and always use this Ref; or
2)
- implements RefCounted
- encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours
- users must ensure no references to the selfRef leak, or are retained outside of a method scope.
- Ref(T, RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.Ref
-
- ref() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- ref() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
-
- ref(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- Ref.IdentityCollection - Class in org.apache.cassandra.utils.concurrent
-
- RefCounted<T> - Interface in org.apache.cassandra.utils.concurrent
-
An object that needs ref counting does the two following:
- defines a Tidy object that will cleanup once it's gone,
(this must retain no references to the object we're tracking (only its resources and how to clean up))
Then, one of two options:
1) Construct a Ref directly pointing to it, and always use this Ref; or
2)
- implements RefCounted
- encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours
- users must ensure no references to the selfRef leak, or are retained outside of a method scope.
- RefCounted.Tidy - Interface in org.apache.cassandra.utils.concurrent
-
- RefCountedMemory - Class in org.apache.cassandra.cache
-
- RefCountedMemory(long) - Constructor for class org.apache.cassandra.cache.RefCountedMemory
-
- reference() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- reference() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.DurationType
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.ListType
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.MapType
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- referencesDuration() - Method in class org.apache.cassandra.db.marshal.UserType
-
- referencesUserType(String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.ListType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.MapType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.SetType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- referencesUserType(String) - Method in class org.apache.cassandra.db.marshal.UserType
-
- ReflectionUtils - Class in org.apache.cassandra.utils
-
- ReflectionUtils() - Constructor for class org.apache.cassandra.utils.ReflectionUtils
-
- Refresh - Class in org.apache.cassandra.tools.nodetool
-
- Refresh() - Constructor for class org.apache.cassandra.tools.nodetool.Refresh
-
- refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
-
- refreshMaxNativeProtocolVersion() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- refreshMaxNegotiableProtocolVersion() - Method in class org.apache.cassandra.service.NativeTransportService
-
- refreshSizeEstimates() - Method in class org.apache.cassandra.service.StorageService
-
- refreshSizeEstimates() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces refresh of values stored in system.size_estimates of all column families.
- refreshSizeEstimates() - Method in class org.apache.cassandra.tools.NodeProbe
-
- RefreshSizeEstimates - Class in org.apache.cassandra.tools.nodetool
-
- RefreshSizeEstimates() - Constructor for class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
-
- refs - Variable in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- Refs<T extends RefCounted<T>> - Class in org.apache.cassandra.utils.concurrent
-
A collection of managed Ref references to RefCounted objects, and the objects they are referencing.
- Refs() - Constructor for class org.apache.cassandra.utils.concurrent.Refs
-
- Refs(Map<T, Ref<T>>) - Constructor for class org.apache.cassandra.utils.concurrent.Refs
-
- RefViewFragment(List<SSTableReader>, Iterable<Memtable>, Refs<SSTableReader>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- Region(long, ByteBuffer) - Constructor for class org.apache.cassandra.io.util.MmappedRegions.Region
-
- regions - Variable in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
-
- register(Class<? extends RowFilter.UserExpression>, RowFilter.UserExpression.Deserializer) - Static method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
-
- register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
-
Register for interesting state changes.
- register(IndexRegistry) - Method in interface org.apache.cassandra.index.Index
-
An index must be registered in order to be able to either subscribe to update events on the base
table and/or to provide Searcher functionality for reads.
- register(IndexRegistry) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- register(IndexRegistry) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- register(CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- register(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
-
- register() - Static method in class org.apache.cassandra.service.GCInspector
-
- register(MigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
-
- register(INotificationConsumer) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
-
Register a new subscriber to this tracker.
- register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
-
- register(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- register() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
Register to be signalled once allPriorOpsAreFinished() or allPriorOpsAreFinishedOrSafe() may return true
- register() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal
- register(Timer.Context) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal.
- registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Register interest for Failure Detector events.
- registerIndex(Index) - Method in interface org.apache.cassandra.index.IndexRegistry
-
- registerIndex(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
IndexRegistry methods
- registerMBean() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
Deprecated.
- registerMBean() - Method in class org.apache.cassandra.hints.HintsService
-
- registerMBean(Metric, ObjectName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.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, String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
-
- registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
-
- registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- registerMBean(Object, ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- registerMBean(Object, String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- registerMBean(Object, String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
-
- RegisterMessage - Class in org.apache.cassandra.transport.messages
-
- RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
-
- registerMeter(String) - Method in class org.apache.cassandra.metrics.ClientMetrics
-
- registerParentRepairSession(UUID, InetAddress, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, long, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- registerReceiving(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- registerVerbHandlers(MessagingService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
-
Register a verb and the corresponding verb handler with the
Messaging Service.
- regular(CFMetaData, ByteBuffer, ByteBuffer, ByteBuffer, long) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- regular(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
-
- REGULAR_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
-
- 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
-
- regularDef(CFMetaData, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- regularDef(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- regularOperations() - Method in class org.apache.cassandra.cql3.Operations
-
Returns the operation on regular columns.
- regulars - Variable in class org.apache.cassandra.db.PartitionColumns
-
- regularStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
-
- REINSERT_OVERFLOWED_TTL_OPTION_DESCRIPTION - Static variable in class org.apache.cassandra.tools.StandaloneScrubber
-
- rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- relaseAllExcept(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- relation(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- relation(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.CqlParser
-
- Relation - Class in org.apache.cassandra.cql3
-
- Relation() - Constructor for class org.apache.cassandra.cql3.Relation
-
- relationOrExpression(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- relationOrExpression(WhereClause.Builder) - Method in class org.apache.cassandra.cql3.CqlParser
-
- relations - Variable in class org.apache.cassandra.cql3.WhereClause
-
- relationsToWhereClause(List<Relation>) - Static method in class org.apache.cassandra.db.view.View
-
- relationType() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- relationType() - Method in class org.apache.cassandra.cql3.CqlParser
-
- relationType - Variable in class org.apache.cassandra.cql3.Relation
-
- relativeFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- release() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- release() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- release() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- release() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- release() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
-
- release() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
-
To be called when this buffer is no longer in use.
- release() - Method in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
- release() - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
- release() - Method in class org.apache.cassandra.metrics.SEPMetrics
-
- release() - Method in class org.apache.cassandra.metrics.TableMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ViewWriteMetrics
-
- release(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
-
- release(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
-
- release(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
-
- release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
-
A convenience method for indicating when a particular request has completed
processing, and before a return to the client
- release() - Method in class org.apache.cassandra.scheduler.NoScheduler
-
- release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- release() - Method in class org.apache.cassandra.transport.Frame
-
- release() - Method in class org.apache.cassandra.transport.Server.EndpointPayloadTracker
-
- release() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
Must be called exactly once, when the logical operation for which this Ref was created has terminated.
- release() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release ALL of the references held by this Refs collection
- release(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- release(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release a retained Ref to all of the provided objects; if any is not held, an exception will be thrown
- release(Iterable<? extends Ref<?>>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- release(Iterable<? extends Ref<?>>, Throwable) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- releaseBuffer(ByteBuffer) - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
-
- releaseIfHolds(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release the retained Ref to the provided object, if held, return false otherwise
- releaseIndexes(Operation) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
-
- releaseIntervalLock() - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
-
Release the last acquired interval lock.
- releaseReference() - Method in class org.apache.cassandra.tracing.TraceState
-
- releaseSummary() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- 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.db.view.ViewManager
-
- reload() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Drops and adds new indexes associated with the underlying CF
- reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
-
Reload the triggers which is already loaded, Invoking this will update
the class loader so new jars can be loaded.
- reloadConfiguration(boolean) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- reloadIndexMetadataProperties(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Reloads the sstable metadata from disk.
- reloadTriggerClasses() - Method in class org.apache.cassandra.service.StorageProxy
-
- reloadTriggerClasses() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- reloadTriggers() - Method in class org.apache.cassandra.tools.NodeProbe
-
- ReloadTriggers - Class in org.apache.cassandra.tools.nodetool
-
- ReloadTriggers() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadTriggers
-
- relocateSSTables(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- relocateSSTables(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- relocateSSTables(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- relocateSSTables(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- relocateSSTables(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- relocateSSTables(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- relocateSSTables(int, String, String[]) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RelocateSSTables - Class in org.apache.cassandra.tools.nodetool
-
- RelocateSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.RelocateSSTables
-
- remaining() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
-
- remaining() - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
-
- remaining() - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
-
- remaining - Variable in class org.apache.cassandra.service.pager.PagingState
-
- remainingCount() - Method in class org.apache.cassandra.db.CBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- 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
-
- RemoteSyncTask - Class in org.apache.cassandra.repair
-
RemoteSyncTask sends
SyncRequest
to remote(non-coordinator) node
to repair(stream) data with other replica.
- RemoteSyncTask(RepairJobDesc, InetAddress, InetAddress, List<Range<Token>>) - Constructor for class org.apache.cassandra.repair.RemoteSyncTask
-
- REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- remove(UUID) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
-
- remove(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- remove(K) - Method in interface org.apache.cassandra.cache.ICache
-
- remove(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- remove(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- remove(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- remove() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- remove() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- remove(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- remove() - Method in class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
-
- remove() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
-
- remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
remove endpoint from failure detector
- remove() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
-
- remove() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- remove(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- remove(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- remove() - Method in class org.apache.cassandra.utils.AbstractIterator
-
- remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- remove(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTreeRemoval
-
Remove |elem| from |btree|.
- remove(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- remove(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- remove(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.DynamicList
-
- remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.LockedDynamicList
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- removeAndIgnoreEndpoint(InetAddress) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeByName(String) - Method in class org.apache.cassandra.db.view.TableViews
-
- removeColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- removed - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
-
- removedNonlocal(UUID, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- removeEndpoint(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Remove stored tokens being used by another node
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Removes the endpoint from Gossip but retains endpoint state
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.Cql_Lexer
-
- removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlLexer
-
- removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlParser
-
- removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from moving endpoints
- removeIndex(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
- removeKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace from schema
- removeMessageSink(IMessageSink) - Method in class org.apache.cassandra.net.MessagingService
-
- removeNode(String) - Method in class org.apache.cassandra.service.StorageService
-
Remove a node that has died, attempting to restore the replica count.
- removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
removeToken removes token (and all data associated with
enpoint that had it) from the ring
- removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RemoveNode - Class in org.apache.cassandra.tools.nodetool
-
- RemoveNode() - Constructor for class org.apache.cassandra.tools.nodetool.RemoveNode
-
- removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
called when the repair session is done - either failed or anticompaction has completed
clears out any snapshots created by this repair
- removePostShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
-
Remove a postshutdownhook
- removePreparedStatement(MD5Digest) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- removePreShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
-
Remove a preshutdown hook
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
-
- removeProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
-
Remove progress listener from this publisher.
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
-
- removeRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- removeRow(Row) - Method in interface org.apache.cassandra.index.Index.Indexer
-
Notification that a row was removed from the partition.
- removeShadowedCells(Row, Row, DeletionTime, int) - Static method in class org.apache.cassandra.db.rows.Rows
-
Returns a row that is obtained from the given existing row by removing everything that is shadowed by data in
the update row.
- removeShutdownHook() - Method in class org.apache.cassandra.service.StorageService
-
In the event of forceful termination we need to remove the shutdown hook to prevent hanging (OOM for instance)
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Removes sstable from the strategy, implementations must be able to handle the sstable having already been removed.
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- removeTemporaryDirectories() - Method in class org.apache.cassandra.db.Directories
-
- removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
This method is used to remove information about truncation time for specified column family
- removeUnfinishedLeftovers(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- removeUnfinishedLeftovers(CFMetaData) - 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
-
- removeView(String) - Method in class org.apache.cassandra.db.view.ViewManager
-
- REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removingNonlocal(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- renameColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
-
- renameColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.config.ViewDefinition
-
Replace the column 'from' with 'to' in this materialized view definition's partition,
clustering, or included columns.
- renameIdentifier(ColumnDefinition.Raw, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- renameIdentifier(ColumnDefinition.Raw, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.Relation
-
Renames an identifier in this Relation, if applicable.
- renameIdentifier(ColumnDefinition.Raw, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- renameIdentifier(ColumnDefinition.Raw, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.TokenRelation
-
- renames(UTName, Map<FieldIdentifier, FieldIdentifier>) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- renameWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
-
- reorderTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- Repair - Class in org.apache.cassandra.tools.nodetool
-
- Repair() - Constructor for class org.apache.cassandra.tools.nodetool.Repair
-
- REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- repair_session_max_tree_depth - Variable in class org.apache.cassandra.config.Config
-
- repairAsync(String, Map<String, String>) - Method in class org.apache.cassandra.service.StorageService
-
- repairAsync(String, Map<String, String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- repairAsync(PrintStream, String, Map<String, String>) - Method in class org.apache.cassandra.tools.NodeProbe
-
- repairedAt - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- repairedAt - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- repairedAt - Variable in class org.apache.cassandra.repair.RepairSession
-
- repairedAt - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- repairedAt - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamReader
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- RepairException - Exception in org.apache.cassandra.exceptions
-
Exception thrown during repair
- RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairException(RepairJobDesc, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairJob - Class in org.apache.cassandra.repair
-
RepairJob runs repair on given ColumnFamily.
- RepairJob(RepairSession, String) - Constructor for class org.apache.cassandra.repair.RepairJob
-
Create repair job to run on specific columnfamily
- RepairJobDesc - Class in org.apache.cassandra.repair
-
RepairJobDesc is used from various repair processes to distinguish one RepairJob to another.
- RepairJobDesc(UUID, UUID, String, String, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
-
- repairJobResults - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- RepairMessage - Class in org.apache.cassandra.repair.messages
-
Base class of all repair related request/response messages.
- RepairMessage(RepairMessage.Type, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
-
- RepairMessage.MessageSerializer<T extends RepairMessage> - Interface in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- RepairMessage.Type - Enum in org.apache.cassandra.repair.messages
-
- RepairMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- RepairMessageVerbHandler - Class in org.apache.cassandra.repair
-
Handles all repair related message.
- RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- RepairOption - Class in org.apache.cassandra.repair.messages
-
Repair options.
- RepairOption(RepairParallelism, boolean, boolean, boolean, int, Collection<Range<Token>>, boolean, 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.
- RepairResult - Class in org.apache.cassandra.repair
-
RepairJob's result
- RepairResult(RepairJobDesc, List<SyncStat>) - Constructor for class org.apache.cassandra.repair.RepairResult
-
- RepairRunnable - Class in org.apache.cassandra.repair
-
- RepairRunnable(StorageService, int, RepairOption, String) - Constructor for class org.apache.cassandra.repair.RepairRunnable
-
- RepairRunner - Class in org.apache.cassandra.tools
-
- RepairRunner(PrintStream, StorageServiceMBean, String, Map<String, String>) - Constructor for class org.apache.cassandra.tools.RepairRunner
-
- RepairSession - Class in org.apache.cassandra.repair
-
Coordinates the (active) repair of a list of non overlapping token ranges.
- RepairSession(UUID, UUID, Collection<Range<Token>>, String, RepairParallelism, Set<InetAddress>, long, boolean, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
-
Create new repair session.
- RepairSessionResult - Class in org.apache.cassandra.repair
-
Repair session result
- RepairSessionResult(UUID, String, Collection<Range<Token>>, Collection<RepairResult>) - Constructor for class org.apache.cassandra.repair.RepairSessionResult
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- replace(K, V, V) - Method in interface org.apache.cassandra.cache.ICache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- replace(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- 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(ViewDefinition, CFMetaData) - Method in class org.apache.cassandra.schema.Views
-
Creates a MaterializedViews instance which contains an updated materialized view
- replacedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
- replaceFlushed(Memtable, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Handle a flushed memtable.
- replaceFlushed(Memtable, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- replaceFlushed(Memtable, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- replaceInSitu(Object[], int, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Modifies the provided btree directly.
- replaceInSitu(Object[], Comparator<? super V>, V, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Modifies the provided btree directly.
- replaceKiller(JVMStabilityInspector.Killer) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- replacementQuarantine(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Quarantine endpoint specifically for replacement purposes.
- replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
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
-
- 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_filtering_protection - Variable in class org.apache.cassandra.config.Config
-
- ReplicaCache() - Constructor for class org.apache.cassandra.locator.AbstractReplicationStrategy.ReplicaCache
-
- 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
-
- replicasMissingMostRecentCommit(CFMetaData, int) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- REPLICATED_SYSTEM_KEYSPACE_NAMES - Static variable in class org.apache.cassandra.config.SchemaConstants
-
- replicatedOwnershipStats(TokenMetadata, AbstractReplicationStrategy, InetAddress) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
-
- replication - Variable in class org.apache.cassandra.schema.KeyspaceParams
-
- ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
-
- ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
-
- ReplicationParams - Class in org.apache.cassandra.schema
-
- report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by the receiver of the heartbeat.
- reportCompactionTable(List<Map<String, String>>, int, boolean, PrintStream) - Static method in class org.apache.cassandra.tools.nodetool.CompactionStats
-
- ReporterWrapper - Class in org.apache.cassandra.hadoop
-
A reporter that works with both mapred and mapreduce APIs.
- ReporterWrapper(Reporter) - Constructor for class org.apache.cassandra.hadoop.ReporterWrapper
-
- reportIncomingFile(ColumnFamilyStore, SSTableMultiWriter, StreamSession, int) - Method in interface org.apache.cassandra.streaming.StreamHook
-
- reportOutgoingFile(StreamSession, SSTableReader, OutgoingFileMessage) - Method in interface org.apache.cassandra.streaming.StreamHook
-
- reportRead(UUID, DecoratedKey) - Method in interface org.apache.cassandra.db.StorageHook
-
- reportStreamFuture(StreamSession, StreamResultFuture) - Method in interface org.apache.cassandra.streaming.StreamHook
-
- reportWrite(UUID, PartitionUpdate) - Method in interface org.apache.cassandra.db.StorageHook
-
- Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
-
- request_scheduler - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_id - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_options - Variable in class org.apache.cassandra.config.Config
-
- request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- requestedRows() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
The set of requested rows.
- requestedSlices() - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- RequestExecutionException - Exception in org.apache.cassandra.exceptions
-
- RequestExecutionException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- RequestExecutionException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- requestExtraSync() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Preempts the CLExecutor, telling to to sync immediately
- RequestFailureException - Exception in org.apache.cassandra.exceptions
-
- RequestFailureException(ExceptionCode, ConsistencyLevel, int, int, Map<InetAddress, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.RequestFailureException
-
- RequestFailureReason - Enum in org.apache.cassandra.exceptions
-
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- requestNames() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
Return only the column names requested by the user, excluding those added for post-query re-orderings,
see definition of names and columnCount.
- requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in keyspace
and ranges
from specific node.
- requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in columnFamilies
under keyspace
and ranges
from specific node.
- requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total number of cache requests
- requests - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
Total number of cache requests
- requests - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Streaming requests
- requests - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- requests - Variable in class org.apache.cassandra.streaming.StreamSession
-
- RequestSchedulerOptions - Class in org.apache.cassandra.config
-
- RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
-
- RequestTimeoutException - Exception in org.apache.cassandra.exceptions
-
- RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- RequestValidationException - Exception in org.apache.cassandra.exceptions
-
- RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidations - Class in org.apache.cassandra.cql3.statements
-
Utility methods use to perform request validation.
- require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- require_endpoint_verification - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Whether or not the authenticator requires explicit login.
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- requireAuthorization() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- requireAuthorization() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
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
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
-
- REQUIRES_ALLOW_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Operation
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Operations
-
Checks if one of the operations requires a read.
- requiresRead() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- rescheduleFailedDeletions() - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
Retry all deletions that failed the first time around (presumably b/c the sstable was still mmap'd.)
Useful because there are times when we know GC has been invoked; also exposed as an mbean.
- rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
-
- rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
-
Retry all failed deletions.
- RESERVED_POOL_SPACE_IN_MB - Static variable in class org.apache.cassandra.cache.ChunkCache
-
- reservedTypeNames - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- reset() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Reset this aggregate.
- reset() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Reset the internal state of this Selector
.
- reset() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- reset() - Method in class org.apache.cassandra.cql3.selection.TermSelector
-
- reset() - Method in class org.apache.cassandra.db.ColumnIndex
-
- reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- reset() - Method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
- reset(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
(Re)initializes the tracker, purging all references.
- reset() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
-
- reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
-
- reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
-
- reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
-
- reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
-
- reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- reset(InputStream) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- reset(long) - Method in interface org.apache.cassandra.io.util.BytesReadTracker
-
reset counter to @param count
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Resets this stream to the last marked location.
- reset(DataPosition) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(DataPosition) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(DataPosition) - Method in interface org.apache.cassandra.io.util.RewindableDataInput
-
- reset(DataPosition) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- reset() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- reset(long) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
reset counter to @param count
- reset(long) - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
reset counter to @param count
- reset() - Method in class org.apache.cassandra.metrics.CacheMissMetrics
-
- reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
reconnect to @param remoteEP (after the current message backlog is exhausted).
- reset() - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- reset() - Method in class org.apache.cassandra.utils.DefaultValue
-
- reset() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- reset() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- resetAndTruncate(DataPosition) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Reset the writer so that the next chunk offset written will be the
one of chunkIndex
.
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- resetAndTruncate(DataPosition) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Drops all buffered data that's past the limits of our new file mark + buffer capacity, or syncs and truncates
the underlying file to the marked position
- resetAvailableRanges() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetConfiguration() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetCrc() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- resetDroppedMessagesMap(String) - Method in class org.apache.cassandra.net.MessagingService
-
- resetForTests() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
-
- resetLimit() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- resetLocalSchema() - Static method in class org.apache.cassandra.service.MigrationManager
-
Clear all locally stored schema information and reset schema to initial state.
- resetLocalSchema() - Method in class org.apache.cassandra.service.StorageService
-
- resetLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- resetLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
-
- ResetLocalSchema - Class in org.apache.cassandra.tools.nodetool
-
- ResetLocalSchema() - Constructor for class org.apache.cassandra.tools.nodetool.ResetLocalSchema
-
- resetPreparedStatements() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- resetTidying() - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- resetUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES
- resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- resetWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- resolve() - Method in class org.apache.cassandra.service.DataResolver
-
- resolve() - Method in class org.apache.cassandra.service.DigestResolver
-
- resolve() - Method in class org.apache.cassandra.service.ResponseResolver
-
- resolve(V, V) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.QuickResolver
-
- resolve(BTree.Builder.Resolver) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- resolve(Object[], int, int) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.Resolver
-
- resolveCounter(long, boolean, ByteBuffer, long, boolean, ByteBuffer) - Static method in class org.apache.cassandra.db.Conflicts
-
- resolveIp - Variable in class org.apache.cassandra.tools.nodetool.HostStat
-
- resolver - Variable in class org.apache.cassandra.service.ReadCallback
-
- resolveRegular(long, boolean, int, ByteBuffer, long, boolean, int, ByteBuffer) - Static method in class org.apache.cassandra.db.Conflicts
-
- resource - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- resource - Variable in class org.apache.cassandra.config.CFMetaData
-
- resource() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- resource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- resource - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- resource - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- RESOURCE_ROLE_INDEX - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- ResourceLimits - Class in org.apache.cassandra.net
-
- ResourceLimits() - Constructor for class org.apache.cassandra.net.ResourceLimits
-
- 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
-
- 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
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- response(MessageIn<T>) - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
null message means "response from local write"
- response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- response(MessageIn<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- response(MessageIn<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
-
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
-
- ResponseResolver - Class in org.apache.cassandra.service
-
- ResponseResolver(Keyspace, ReadCommand, ConsistencyLevel, int) - Constructor for class org.apache.cassandra.service.ResponseResolver
-
- responses - Variable in class org.apache.cassandra.service.ResponseResolver
-
- responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
-
- ResponseVerbHandler - Class in org.apache.cassandra.net
-
- ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
-
- restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES
- RestorableMeter - Class in org.apache.cassandra.metrics
-
A meter metric which measures mean throughput as well as fifteen-minute and two-hour
exponentially-weighted moving average throughputs.
- RestorableMeter() - Constructor for class org.apache.cassandra.metrics.RestorableMeter
-
Creates a new, uninitialized RestorableMeter.
- RestorableMeter(double, double) - Constructor for class org.apache.cassandra.metrics.RestorableMeter
-
Restores a RestorableMeter from the last seen 15m and 2h rates.
- restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- Restriction - Interface in org.apache.cassandra.cql3.restrictions
-
Implementation of this class must be immutable.
- Restrictions - Interface in org.apache.cassandra.cql3.restrictions
-
Sets of restrictions
- result - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
-
- result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- resultify(String, RowIterator) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- resultify(String, PartitionIterator) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- ResultMessage - Class in org.apache.cassandra.transport.messages
-
- ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
-
- ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Void - Class in org.apache.cassandra.transport.messages
-
- ResultMetadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
Describes the results of executing this prepared statement
- ResultSet - Class in org.apache.cassandra.cql3
-
- ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet(ResultSet.ResultMetadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet.Codec - Class in org.apache.cassandra.cql3
-
- ResultSet.Flag - Enum in org.apache.cassandra.cql3
-
- ResultSet.PreparedMetadata - Class in org.apache.cassandra.cql3
-
The metadata for the query parameters in a prepared statement.
- ResultSet.ResultMetadata - Class in org.apache.cassandra.cql3
-
The metadata for the results of executing a query or prepared statement.
- resultSetBuilder(QueryOptions, boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- resultSetBuilder(QueryOptions, boolean, AggregationSpecification) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- resume() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
For internal, temporary suspension of background compactions so that we can do exceptional
things like truncate or major compaction
- 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.
- ResumeHandoff - Class in org.apache.cassandra.tools.nodetool
-
- ResumeHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.ResumeHandoff
-
- resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
-
- retain() - Method in class org.apache.cassandra.transport.Frame
-
- retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- retrieveTemporaryBuffer(int) - Static method in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- RetryMessage - Class in org.apache.cassandra.streaming.messages
-
- RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- returnAtLeastOneRow() - Method in class org.apache.cassandra.db.aggregation.GroupMaker
-
Specify if at least one row must be returned.
- returnCode - Variable in exception org.apache.cassandra.exceptions.StartupException
-
- returnCodec - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- reuse() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- reuse(Comparator<? super V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- reverse() - Method in class org.apache.cassandra.cql3.ResultSet
-
- reverse() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- reverse() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- reverse() - Method in class org.apache.cassandra.utils.AsymmetricOrdering
-
- reverse() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- reversed - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- reversed() - Method in class org.apache.cassandra.db.ClusteringComparator
-
- reversed - Variable in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
-
- ReversedType<T> - Class in org.apache.cassandra.db.marshal
-
- reverseIfNeeded(ColumnDefinition) - Method in enum org.apache.cassandra.cql3.statements.Bound
-
Reverses the bound if the column type is a reversed one.
- reverseIterator() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- reverseMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Revokes a set of permissions on a resource from a user.
- revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAllFrom(RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Called before deleting a role with DROP ROLE statement (or the alias provided for compatibility,
DROP USER) so that a new role with the same name wouldn't inherit permissions of the deleted one in the future.
- revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAllOn(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called after a resource is removed (i.e.
- revokePermissionsStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- revokePermissionsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- RevokePermissionsStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokePermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
-
- revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during the execution of a REVOKE ROLE query.
- revokeRoleStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- revokeRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- RevokeRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokeRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokeRoleStatement
-
- rewind() - Method in class org.apache.cassandra.utils.btree.BTreeSearchIterator
-
Reset this Iterator to its starting position
- RewindableDataInput - Interface in org.apache.cassandra.io.util
-
- RewindableDataInputPlusMark() - Constructor for class org.apache.cassandra.io.util.RewindableDataInputStreamPlus.RewindableDataInputPlusMark
-
- RewindableDataInputStreamPlus - Class in org.apache.cassandra.io.util
-
Adds mark/reset functionality to another input stream by caching read bytes to a memory buffer and
spilling to disk if necessary.
- RewindableDataInputStreamPlus(InputStream, int, int, File, int) - Constructor for class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- RewindableDataInputStreamPlus.RewindableDataInputPlusMark - Class in org.apache.cassandra.io.util
-
- rewriteSSTableMetadata(Descriptor, Map<MetadataType, MetadataComponent>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Replace the sstable metadata file (-Statistics.db
) with the given components.
- rewriteSSTableMetadata(Descriptor, Map<MetadataType, MetadataComponent>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- rfpRowsCachedPerQuery - Variable in class org.apache.cassandra.metrics.TableMetrics
-
This histogram records the maximum number of rows ReplicaFilteringProtection
caches at a point in time per query.
- right - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- right - 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
-
- rightBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- rightmostLeaf - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- rightmostParent - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- Ring - Class in org.apache.cassandra.tools.nodetool
-
- Ring() - Constructor for class org.apache.cassandra.tools.nodetool.Ring
-
- RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
-
- RingCache - Class in org.apache.cassandra.client
-
A class for caching the ring map at the client.
- RingCache(Configuration) - Constructor for class org.apache.cassandra.client.RingCache
-
- ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
iterator over the Tokens in the given ring, starting with the token for the node owning start
(which does not have to be a Token in the ring)
- RingPosition<C extends RingPosition<C>> - Interface in org.apache.cassandra.dht
-
Interface representing a position on the ring.
- 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(String) - Static method in class org.apache.cassandra.auth.RoleResource
-
Creates a RoleResource representing an individual Role.
- role - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- role_manager - Variable in class org.apache.cassandra.config.Config
-
- ROLE_MEMBERS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- ROLE_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- RoleManagementStatement - Class in org.apache.cassandra.cql3.statements
-
- RoleManagementStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- roleName(RoleName) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- roleName(RoleName) - Method in class org.apache.cassandra.cql3.CqlParser
-
- RoleName - Class in org.apache.cassandra.cql3
-
- RoleName() - Constructor for class org.apache.cassandra.cql3.RoleName
-
- roleOption(RoleOptions) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- roleOption(RoleOptions) - Method in class org.apache.cassandra.cql3.CqlParser
-
- RoleOptions - Class in org.apache.cassandra.auth
-
- RoleOptions() - Constructor for class org.apache.cassandra.auth.RoleOptions
-
- roleOptions(RoleOptions) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- roleOptions(RoleOptions) - Method in class org.apache.cassandra.cql3.CqlParser
-
- RoleResource - Class in org.apache.cassandra.auth
-
IResource implementation representing database roles.
- roleResource() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- roleResource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- Roles - Class in org.apache.cassandra.auth
-
- Roles() - Constructor for class org.apache.cassandra.auth.Roles
-
- roles_cache_max_entries - Variable in class org.apache.cassandra.config.Config
-
- roles_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- roles_validity_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RolesCache - Class in org.apache.cassandra.auth
-
- RolesCache(IRoleManager) - Constructor for class org.apache.cassandra.auth.RolesCache
-
- RolesCacheMBean - Interface in org.apache.cassandra.auth
-
Retained since CASSANDRA-7715 for backwards compatibility of MBean interface
classes.
- root() - Static method in class org.apache.cassandra.auth.DataResource
-
- root() - Static method in class org.apache.cassandra.auth.FunctionResource
-
- root() - Static method in class org.apache.cassandra.auth.JMXResource
-
- ROOT - Static variable in class org.apache.cassandra.auth.Resources
-
Deprecated.
- root() - Static method in class org.apache.cassandra.auth.RoleResource
-
- root - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- roundBufferSize(long) - Method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
-
- roundForCaching(int, boolean) - Static method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
-
- RoundRobinScheduler - Class in org.apache.cassandra.scheduler
-
A very basic Round Robin implementation of the RequestScheduler.
- RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- roundUp - Static variable in class org.apache.cassandra.cache.ChunkCache
-
- roundUpNormal(int) - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
- Row(Map<String, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- Row(List<ColumnSpecification>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- row(CFMetaData, DecoratedKey, boolean) - Static method in class org.apache.cassandra.db.EmptyIterators
-
- row(Object...) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
-
Adds the row identifier by the provided clustering and return a builder for that row.
- Row - Interface in org.apache.cassandra.db.rows
-
Storage engine representation of a row.
- row(Object...) - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
-
- Row.Builder - Interface in org.apache.cassandra.db.rows
-
Interface for building rows.
- Row.Deletion - Class in org.apache.cassandra.db.rows
-
A row deletion/tombstone.
- Row.Merger - Class in org.apache.cassandra.db.rows
-
Utility class to help merging rows from multiple inputs (UnfilteredRowIterators).
- Row.SimpleBuilder - Interface in org.apache.cassandra.db.rows
-
Row builder interface geared towards human.
- row_cache_class_name - Variable in class org.apache.cassandra.config.Config
-
- row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- row_cache_save_period - Variable in class org.apache.cassandra.config.Config
-
- row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- RowAndDeletionMergeIterator - Class in org.apache.cassandra.db.rows
-
An iterator that merges a source of rows with the range tombstone and partition level deletion of a give partition.
- RowAndDeletionMergeIterator(CFMetaData, DecoratedKey, DeletionTime, ColumnFilter, Row, boolean, EncodingStats, Iterator<Row>, Iterator<RangeTombstone>, boolean) - Constructor for class org.apache.cassandra.db.rows.RowAndDeletionMergeIterator
-
- RowBuilder(CFMetaData, Object...) - Constructor for class org.apache.cassandra.db.SimpleBuilders.RowBuilder
-
- rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- rowCache - Variable in class org.apache.cassandra.service.CacheService
-
- rowCacheHit - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Number of row cache hits
- rowCacheHitOutOfRange - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Row cache hits, but result out of range
- RowCacheKey - Class in org.apache.cassandra.cache
-
- RowCacheKey(Pair<String, String>, byte[]) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(Pair<String, String>, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(Pair<String, String>, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- rowCacheMiss - Variable in class org.apache.cassandra.metrics.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.service.CacheService.RowCacheSerializer
-
- rowComparator() - Method in class org.apache.cassandra.db.ClusteringComparator
-
A comparator for rows.
- rowCount() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- rowCount() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
-
The number of Row
objects in this cached partition.
- rowCount() - Method in class org.apache.cassandra.utils.MerkleTree
-
- rowCount() - Method in class org.apache.cassandra.utils.MerkleTrees
-
- RowDiffListener - Interface in org.apache.cassandra.db.rows
-
Interface that allows to act on the result of merging multiple rows.
- rowEstimate - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- RowFilter - Class in org.apache.cassandra.db.filter
-
A filter on which rows a given query should include or exclude.
- RowFilter(List<RowFilter.Expression>) - Constructor for class org.apache.cassandra.db.filter.RowFilter
-
- rowFilter() - Method in class org.apache.cassandra.db.ReadCommand
-
Filters/Resrictions on CQL rows.
- 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).
- rowFilterFromThrift(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
-
- RowIndexEntry<T> - Class in org.apache.cassandra.db
-
Binary format of RowIndexEntry
is defined as follows:
{@code
(long) position (64 bit long, vint encoded)
(int) serialized size of data that follows (32 bit int, vint encoded)
-- following for indexed entries only (so serialized size > 0)
(int) DeletionTime.localDeletionTime
(long) DeletionTime.markedForDeletionAt
(int) number of IndexInfo objects (32 bit int, vint encoded)
(*) serialized IndexInfo objects, see below
(*) offsets of serialized IndexInfo objects, since version "ma" (3.0)
Each IndexInfo object's offset is relative to the first IndexInfo object.
- RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
-
- RowIndexEntry.IndexInfoRetriever - Interface in org.apache.cassandra.db
-
- RowIndexEntry.IndexSerializer<T> - Interface in org.apache.cassandra.db
-
- RowIndexEntry.Serializer - Class in org.apache.cassandra.db
-
- rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- rowIterator() - Method in class org.apache.cassandra.db.partitions.FilteredPartition
-
- RowIterator - Interface in org.apache.cassandra.db.rows
-
An iterator over rows belonging to a partition.
- RowIterators - Class in org.apache.cassandra.db.rows
-
Static methods to work with row iterators.
- rowMark - Variable in class org.apache.cassandra.service.pager.PagingState
-
- RowPositionSerializer() - Constructor for class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
-
- rowPositionSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
-
- rows - Variable in class org.apache.cassandra.cql3.ResultSet
-
- Rows - Class in org.apache.cassandra.db.rows
-
Static utilities to work on Row objects.
- Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- rowsCounted() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
The number of rows counted.
- rowsCountedInCurrentPartition() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
-
The number of rows counted in the current partition.
- rowsOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowsOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- 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.
- rowToJson(List<ByteBuffer>, ProtocolVersion, ResultSet.ResultMetadata) - Static method in class org.apache.cassandra.cql3.selection.Selection
-
- rpc_address - Variable in class org.apache.cassandra.config.Config
-
- rpc_interface - Variable in class org.apache.cassandra.config.Config
-
- rpc_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
-
- rpc_keepalive - Variable in class org.apache.cassandra.config.Config
-
- rpc_listen_backlog - Variable in class org.apache.cassandra.config.Config
-
- rpc_max_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_min_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_port - Variable in class org.apache.cassandra.config.Config
-
- rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_server_type - Variable in class org.apache.cassandra.config.Config
-
- rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rpcReady(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- RTBoundCloser - Class in org.apache.cassandra.db.transform
-
A transformation that appends an RT bound marker to row iterators in case they don't have one.
- RTBoundValidator - Class in org.apache.cassandra.db.transform
-
A validating transformation that sanity-checks the sequence of RT bounds and boundaries in every partition.
- RTBoundValidator.Stage - Enum in org.apache.cassandra.db.transform
-
- run() - Method in interface org.apache.cassandra.concurrent.InfiniteLoopExecutor.InterruptibleRunnable
-
- run() - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
-
- run() - Method in class org.apache.cassandra.db.view.ViewBuilder
-
- run() - Method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
-
- run() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
A new connection will either stream or message for its entire lifetime: because streaming
bypasses the InputStream implementations to use sendFile, we cannot begin buffering until
we've determined the type of the connection.
- run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
-
- run() - Method in class org.apache.cassandra.net.MessagingService.SocketThread
-
- run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- run() - Method in class org.apache.cassandra.repair.AnticompactionTask
-
- run() - Method in class org.apache.cassandra.repair.RepairJob
-
Runs repair job.
- run() - Method in class org.apache.cassandra.repair.SnapshotTask
-
- run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
- run() - Method in class org.apache.cassandra.repair.SyncTask
-
Compares trees, and triggers repairs for any ranges that mismatch.
- run() - Method in class org.apache.cassandra.repair.ValidationTask
-
Send ValidationRequest to replica
- run() - Method in class org.apache.cassandra.repair.Validator
-
Called after the validation lifecycle to respond with the now valid tree.
- run(INodeProbeFactory, Output) - Method in class org.apache.cassandra.tools.NodeTool.CassHelp
-
- run(INodeProbeFactory, Output) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
-
- run() - Method in class org.apache.cassandra.tools.RepairRunner
-
- run() - Method in class org.apache.cassandra.transport.Client
-
- run() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread.Clean
-
- run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- run() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runIndexSummaryRedistribution(IndexSummaryRedistribution) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- runInGossipStageBlocking(Runnable) - Static method in class org.apache.cassandra.gms.Gossiper
-
- runInternal() - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
-
- runMayThrow() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
For internal use and testing only.
- runMayThrow() - Method in class org.apache.cassandra.repair.RepairRunnable
-
- runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runOnAbort(Runnable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- runOnClose(int) - Method in class org.apache.cassandra.db.transform.BasePartitions
-
- runOnClose(int) - Method in class org.apache.cassandra.db.transform.BaseRows
-
- runOnClose(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- runOnCommit(Runnable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- runtimeProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- runWithCompactionsDisabled(Callable<V>, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- runWithThreadName(Runnable, String) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- S - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- S - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- S - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- S - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- SA<T extends java.nio.Buffer> - Class in org.apache.cassandra.index.sasi.sa
-
- SA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.SA
-
- SafeMemory - Class in org.apache.cassandra.io.util
-
- SafeMemory(long) - Constructor for class org.apache.cassandra.io.util.SafeMemory
-
- SafeMemoryWriter - Class in org.apache.cassandra.io.util
-
- SafeMemoryWriter(long) - Constructor for class org.apache.cassandra.io.util.SafeMemoryWriter
-
- sampleKeyRange() - Method in class org.apache.cassandra.service.StorageService
-
#Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
- sampleKeyRange() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
- sampleKeyRange() - Method in class org.apache.cassandra.tools.NodeProbe
-
- sampleLatencyNanos - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- SamplerResult(List<Counter<S>>, long) - Constructor for class org.apache.cassandra.utils.TopKSampler.SamplerResult
-
- samplers - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- SASIIndex - Class in org.apache.cassandra.index.sasi
-
- SASIIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.SASIIndex
-
- satisfiedBy(Unfiltered, Row, boolean) - Method in class org.apache.cassandra.index.sasi.plan.Operation
-
Recursive "satisfies" checks based on operation
and data from the lower level members using depth-first search
and bubbling the results back to the top level caller.
- saveBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- saveBloomFilter(Descriptor, IFilter) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- saveCaches() - Method in class org.apache.cassandra.service.CacheService
-
- saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
save row and key caches
- saved_caches_directory - Variable in class org.apache.cassandra.config.Config
-
- savePaxosCommit(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosPromise(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- saveSummary() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Save index summary to Summary.db file.
- saveSummary(Descriptor, DecoratedKey, DecoratedKey, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Save index summary to Summary.db file.
- saveSystemKeyspacesSchema() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
Add entries to system_schema.* for the hardcoded system keyspaces
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- saveTruncationRecord(ColumnFamilyStore, long, CommitLogPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- ScalarFunction - Interface in org.apache.cassandra.cql3.functions
-
Determines a single output value based on a single input value.
- ScannerList(List<ISSTableScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- ScheduledExecutors - Class in org.apache.cassandra.concurrent
-
Centralized location for shared executors
- ScheduledExecutors() - Constructor for class org.apache.cassandra.concurrent.ScheduledExecutors
-
- 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.
- scheduleHintDelivery(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
Deprecated.
- scheduleHintDelivery(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
Deprecated.
force hint delivery to an endpoint
- scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- scheduleSegmentFlush(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- scheduleTimeout(int, long, TimeUnit) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Schedule timeout task to release reference for file sent.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- Schema - Class in org.apache.cassandra.config
-
- Schema() - Constructor for class org.apache.cassandra.config.Schema
-
Initialize empty schema object and load the hardcoded system tables
- schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- schema_cident() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- schema_cident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- SCHEMA_DELAY_MILLIS - Static variable in class org.apache.cassandra.service.StorageService
-
- SCHEMA_KEYSPACE_NAME - Static variable in class org.apache.cassandra.config.SchemaConstants
-
- SchemaAlteringStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that alter the schema.
- SchemaAlteringStatement() - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- SchemaAlteringStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- schemaCallback(Supplier<Function<Descriptor, CFMetaData>>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
-
Schema callback to retrieve the schema of a table.
- schemaCallback - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
-
- SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String, List<String>) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- SchemaCheckVerbHandler - Class in org.apache.cassandra.db
-
- SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- SchemaConstants - Class in org.apache.cassandra.config
-
- SchemaConstants() - Constructor for class org.apache.cassandra.config.SchemaConstants
-
- SchemaKeyspace - Class in org.apache.cassandra.schema
-
system_schema.* tables and methods for manipulating them.
- SchemaKeyspaceTables - Class in org.apache.cassandra.schema
-
- schemaVersionToString(UUID) - Static method in class org.apache.cassandra.config.Schema
-
Converts the given schema version to a string.
- scratchBuffer - Static variable in class org.apache.cassandra.io.util.DataOutputBuffer
-
Scratch buffers used mostly for serializing in memory.
- scrub(boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- scrub(boolean, boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- scrub(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- scrub(PrintStream, boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Scrub - Class in org.apache.cassandra.tools.nodetool
-
- Scrub() - Constructor for class org.apache.cassandra.tools.nodetool.Scrub
-
- Scrubber - Class in org.apache.cassandra.db.compaction
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, OutputHandler, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber.NegativeLocalDeletionInfoMetrics - Class in org.apache.cassandra.db.compaction
-
- Scrubber.ScrubResult - Class in org.apache.cassandra.db.compaction
-
- scrubDataDirectories(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
and compacted sstables.
- ScrubResult(Scrubber) - Constructor for class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
-
- scrubWithResult() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- scts(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
-
- search(Clustering) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- search(ReadExecutionController) - Method in interface org.apache.cassandra.index.Index.Searcher
-
- search(ReadExecutionController) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
-
- search(Expression) - Method in interface org.apache.cassandra.index.sasi.conf.view.TermTree
-
- search(AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
Search for rows which match all of the terms inside the given expression in the index file.
- search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.IndexMemtable
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.MemIndex
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
-
- search(Expression.Op, String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentPrefixTrie
-
- search(Expression.Op, String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentSuffixTrie
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex
-
- search(Expression) - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
-
- search(C) - Method in class org.apache.cassandra.utils.IntervalTree
-
- searchConcurrencyFactor() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- searchDeletionTime(Clustering) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns the DeletionTime for the tombstone overlapping name
(there can't be more than one),
or null if name
is not covered by any tombstone.
- searcherFor(ReadCommand) - Method in interface org.apache.cassandra.index.Index
-
Factory method for query time search helper.
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- searchIterator(ColumnFilter, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- searchIterator(ColumnFilter, boolean) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
- searchIterator(ColumnFilter, boolean) - Method in interface org.apache.cassandra.db.partitions.Partition
-
Returns an iterator that allows to search specific rows efficiently.
- searchIterator() - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- searchIterator() - Method in interface org.apache.cassandra.db.rows.Row
-
An iterator to efficiently search data for a given column.
- SearchIterator<K,V> - Interface in org.apache.cassandra.utils
-
- searchMemtable(Expression) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- SearchResult(T, int, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
-
- SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
-
- SecondaryIndexBuilder - Class in org.apache.cassandra.index
-
Manages building an entire index from column family data.
- SecondaryIndexBuilder() - Constructor for class org.apache.cassandra.index.SecondaryIndexBuilder
-
- SecondaryIndexManager - Class in org.apache.cassandra.index
-
Handles the core maintenance functionality associated with indexes: adding/removing them to or from
a table, (re)building during bootstrap or other streaming operations, flushing, reloading metadata
and so on.
- SecondaryIndexManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.index.SecondaryIndexManager
-
- secondEndpoint - Variable in class org.apache.cassandra.repair.SyncTask
-
- secondValue - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiEQRestriction
-
- secondValue - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiSliceRestriction
-
- sections - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamReader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sections - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SecurityThreadGroup - Class in org.apache.cassandra.security
-
- SecurityThreadGroup(String, Set<String>, SecurityThreadGroup.ThreadInitializer) - Constructor for class org.apache.cassandra.security.SecurityThreadGroup
-
- SecurityThreadGroup.ThreadInitializer - Interface in org.apache.cassandra.security
-
- seed_provider - Variable in class org.apache.cassandra.config.Config
-
- SeedProvider - Interface in org.apache.cassandra.locator
-
- seek(long) - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
-
- seek(InputPosition) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- seek(InputPosition) - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
-
- seek(InputPosition) - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- seek(long) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
-
- seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- seekToPosition(long) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
-
- segmentId - Variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- SegmentIterator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentIterator
-
- segmentManager - Variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- SegmentReadException(String, boolean) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentReadException
-
- segments - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
-
- select - Variable in class org.apache.cassandra.config.ViewDefinition
-
- select(Function<View, Iterable<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- select(ColumnDefinition, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
-
- select(SSTableSet) - Method in class org.apache.cassandra.db.lifecycle.View
-
- select(SSTableSet, Predicate<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.View
-
- select(SSTableSet, DecoratedKey) - Static method in class org.apache.cassandra.db.lifecycle.View
-
- select(Map.Entry<? extends K, ? extends V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Cursor
-
Called for each
Map.Entry
in the
Trie
.
- select(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
-
Returns the Map.Entry
whose key is closest in a bitwise XOR
metric to the given key.
- select(K, Cursor<? super K, ? super V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
-
Iterates through the
Trie
, starting with the entry whose bitwise
value is closest in an XOR metric to the given key.
- selectable - Variable in class org.apache.cassandra.cql3.selection.RawSelector
-
- Selectable - Interface in org.apache.cassandra.cql3.selection
-
- Selectable.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.WithFieldSelection - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFieldSelection.Raw - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFunction - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFunction.Raw - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithTerm - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithTerm.Raw - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithToJSonFunction - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.selection
-
- selectAndReference(Function<View, Iterable<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- selectClause() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- selectClause() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selectClause - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
-
- selectFunction(SSTableSet) - Static method in class org.apache.cassandra.db.lifecycle.View
-
- Selection - Class in org.apache.cassandra.cql3.selection
-
- Selection(CFMetaData, List<ColumnDefinition>, SelectionColumnMapping, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selection
-
- selection(PartitionColumns) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
-
A filter that only fetches/queries the provided columns.
- selection(CFMetaData, PartitionColumns) - 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.ResultSetBuilder - Class 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.
- SelectionColumnMapping - Class in org.apache.cassandra.cql3.selection
-
Separately maintains the ColumnSpecifications and their mappings to underlying
columns as we may receive null mappings.
- SelectionColumns - Interface in org.apache.cassandra.cql3.selection
-
Represents a mapping between the actual columns used to satisfy a Selection
and the column definitions included in the resultset metadata for the query.
- selectionDeserializer - Static variable in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- SelectionDeserializer() - Constructor for class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
-
- selectionDeserializer - Static variable in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- selectionFunctionArgs() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- selectionFunctionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- selector() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Selector - Class in org.apache.cassandra.cql3.selection
-
A Selector
is used to convert the data returned by the storage engine into the data requested by the
user.
- Selector() - Constructor for class org.apache.cassandra.cql3.selection.Selector
-
- Selector.Factory - Class in org.apache.cassandra.cql3.selection
-
A factory for Selector
instances.
- 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.PartitionColumns
-
- 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 class org.apache.cassandra.db.PartitionRangeReadCommand
-
- selectsClustering(DecoratedKey, Clustering) - Method in interface org.apache.cassandra.db.ReadQuery
-
- selectsClustering(DecoratedKey, Clustering) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- selectsClustering(DecoratedKey, Clustering) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- selectsFullPartition() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- 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.Group
-
- selectsFullPartition() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- selectsKey(DecoratedKey) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
-
- selectsKey(DecoratedKey) - Method in interface org.apache.cassandra.db.ReadQuery
-
- selectsKey(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- selectsKey(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- selectStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- selectStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- SelectStatement - Class in org.apache.cassandra.cql3.statements
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(CFMetaData, int, SelectStatement.Parameters, Selection, StatementRestrictions, boolean, AggregationSpecification, Comparator<List<ByteBuffer>>, Term, Term) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
-
- SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- selectValue(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
-
Returns the value whose key is closest in a bitwise XOR metric to
the provided key.
- selfRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- selfRef() - Method in interface org.apache.cassandra.utils.concurrent.SelfRefCounted
-
- SelfRefCounted<T extends SelfRefCounted<T>> - Interface in org.apache.cassandra.utils.concurrent
-
- selfRefs(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- sendBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- sendingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of sending summaries
- sendMessage(StreamMessage) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- sendMessages(Collection<? extends StreamMessage>) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Enqueue messages to be sent.
- sendMigrationMessage(MigrationCoordinator.Callback) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendOneWay(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- sendReply(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
Send a non-mutation message to a given endpoint.
- sendRR(MessageOut<?>, InetAddress, AbstractWriteResponseHandler<?>, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
Send a mutation message or a Paxos Commit to a given endpoint.
- sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRRWithFailure(MessageOut, InetAddress, IAsyncCallbackWithFailure) - Method in class org.apache.cassandra.net.MessagingService
-
- sendToHintedEndpoints(Mutation, Iterable<InetAddress>, AbstractWriteResponseHandler<IMutation>, String, Stage) - Static method in class org.apache.cassandra.service.StorageProxy
-
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node
is not available.
- sent() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- separator - Static variable in class org.apache.cassandra.io.sstable.Component
-
- SEPExecutor - Class in org.apache.cassandra.concurrent
-
- SEPMetrics - Class in org.apache.cassandra.metrics
-
- SEPMetrics(SEPExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.SEPMetrics
-
Create metrics for the given LowSignalExecutor.
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- SequentialWriter - Class in org.apache.cassandra.io.util
-
Adds buffering, mark, and fsyncing to OutputStream.
- SequentialWriter(File) - 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.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
-
- serializationFlags() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- SerializationHeader - Class in org.apache.cassandra.db
-
- SerializationHeader(boolean, CFMetaData, PartitionColumns, EncodingStats) - Constructor for class org.apache.cassandra.db.SerializationHeader
-
- SerializationHeader.Component - Class in org.apache.cassandra.db
-
We need the CFMetadata 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(CFMetaData, int, SerializationHelper.Flag, ColumnFilter) - Constructor for class org.apache.cassandra.db.rows.SerializationHelper
-
- SerializationHelper(CFMetaData, int, SerializationHelper.Flag) - Constructor for class org.apache.cassandra.db.rows.SerializationHelper
-
- SerializationHelper.Flag - Enum in org.apache.cassandra.db.rows
-
Flag affecting deserialization behavior (this only affect counters in practice).
- serialize(K, DataOutputPlus, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- serialize(CFMetaData, DataOutputPlus, int) - Method in class org.apache.cassandra.config.CFMetaData.Serializer
-
- serialize(TypeCodec<?>, ProtocolVersion, Object) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- serialize(AggregationSpecification, DataOutputPlus, int) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
-
- serialize(GroupingState, DataOutputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
-
- serialize(Clustering, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- serialize(Clustering, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- serialize(ClusteringBoundOrBoundary, 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, CFMetaData) - Method in class org.apache.cassandra.db.DataRange.Serializer
-
- serialize(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- serialize(ClusteringIndexFilter, DataOutputPlus, int) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
-
- serialize(ColumnFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
-
- serialize(ColumnSubselection, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
-
- serialize(DataLimits, DataOutputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
-
- serialize(RowFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
-
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
-
- serialize(DataOutputPlus, CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstoneList
-
- 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(RowIndexEntry<T>, DataOutputPlus, ByteBuffer) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- serialize(DataOutputPlus, IndexInfo.Serializer, ByteBuffer) - Method in class org.apache.cassandra.db.RowIndexEntry
-
- serialize(RowIndexEntry<IndexInfo>, DataOutputPlus, ByteBuffer) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serialize(CellPath, DataOutputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
-
- serialize(EncodingStats, DataOutputPlus) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
-
- serialize(UnfilteredRowIterator, ColumnFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- serialize(UnfilteredRowIterator, ColumnFilter, DataOutputPlus, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- serialize(UnfilteredRowIterator, SerializationHeader, ColumnFilter, DataOutputPlus, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- serialize(Unfiltered, SerializationHeader, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serialize(Unfiltered, SerializationHeader, DataOutputPlus, long, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serialize(Version, SerializationHeader.Component, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- serialize(Slice, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
-
- serialize(Slices, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Slices.Serializer
-
- serialize(TruncateResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serialize(WriteResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.WriteResponse.Serializer
-
- serialize(AbstractBounds<T>, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serialize(String, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(Token, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serialize(EchoMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- serialize(HintMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
-
- serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- serialize(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
-
- serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
-
- serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
-
- serialize(T, DataOutputPlus, int) - Method in class org.apache.cassandra.io.ForwardingVersionedSerializer
-
- serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISerializer
-
Serialize the specified type into the specified DataOutput instance.
- serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(IndexInfo, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
-
- serialize(IndexSummary, DataOutputPlus, boolean) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- serialize(Version, CompactionMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serialize(Version, T, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Serialize metadata component to given output.
- serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus, Version) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Serialize given metadata components
- serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus, Version) - Method in class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
-
Deprecated.
Legacy serialization is only used for SSTable level reset.
- serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus, Version) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- serialize(Version, StatsMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serialize(Version, ValidationMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.net.MessageOut
-
- serialize(DataOutputPlus, InetAddress, MessagingService.Verb, Map<String, byte[]>, T, int) - Static method in class org.apache.cassandra.net.MessageOut
-
- serialize(DataOutputPlus, InetAddress, MessagingService.Verb, Map<String, byte[]>, T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.net.MessageOut
-
- serialize(PingMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.net.PingMessage.PingMessageSerializer
-
- serialize(AnticompactionRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- serialize(CleanupMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- serialize(PrepareMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
-
- serialize(RepairMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serialize(SnapshotMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- serialize(SyncRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serialize(ValidationRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serialize(NodePair, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serialize(IndexMetadata, DataOutputPlus, int) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
-
- serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- serialize(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- serialize(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- serialize(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
-
- serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- serialize(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- serialize(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- serialize(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- serialize(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- serialize(CounterCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
-
- serialize(KeyCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- serialize(RowCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- serialize(Collection<Mutation>, DataOutputPlus, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serialize(ProtocolVersion) - Method in class org.apache.cassandra.service.pager.PagingState
-
- serialize(Commit, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serialize(PrepareResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serialize(DataOutputStreamPlus, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- serialize(StreamMessage, DataOutputStreamPlus, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- serialize(V, DataOutputStreamPlus, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- serialize(StreamRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serialize(StreamSummary, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serialize(Tracing.TraceType) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
- serialize(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
-
- serialize(EnumSet<Frame.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
- serialize(Boolean, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serialize(EstimatedHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- serialize(IFilter, DataOutputPlus) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- serialize(IntervalTree<C, D, I>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serialize(MerkleTree, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serialize(MerkleTrees, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
-
- serialize(DataOutput) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serialize(StreamingHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serialize(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeAsLegacyPartition(ReadCommand, UnfilteredRowIterator, DataOutputPlus, int) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- serializeData(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
-
- serializedSize(CFMetaData, int) - Method in class org.apache.cassandra.config.CFMetaData.Serializer
-
- serializedSize() - Method in enum org.apache.cassandra.cql3.Operator
-
- serializedSize(AggregationSpecification, int) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
-
- serializedSize(GroupingState, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
-
- serializedSize(Clustering, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- serializedSize(ClusteringBoundOrBoundary, 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, CFMetaData) - Method in class org.apache.cassandra.db.DataRange.Serializer
-
- serializedSize(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- serializedSize(ClusteringIndexFilter, int) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
-
- serializedSize(ColumnFilter, int) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
-
- serializedSize(ColumnSubselection, int) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
-
- serializedSize(DataLimits, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
-
- serializedSize(RowFilter, int) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
-
- serializedSize(int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
-
- serializedSize(CFMetaData) - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstoneList
-
- 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(CellPath) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
-
- serializedSize(EncodingStats) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
-
- serializedSize(UnfilteredRowIterator, ColumnFilter, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- serializedSize(Unfiltered, SerializationHeader, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serializedSize(Unfiltered, SerializationHeader, long, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serializedSize(Version, SerializationHeader.Component) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- serializedSize(Slice, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
-
- serializedSize(Slices, int) - Method in class org.apache.cassandra.db.Slices.Serializer
-
- serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serializedSize(WriteResponse, int) - Method in class org.apache.cassandra.db.WriteResponse.Serializer
-
- serializedSize(AbstractBounds<T>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(Token, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serializedSize(EchoMessage, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serializedSize(HintMessage, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
-
- serializedSize() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- serializedSize() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- serializedSize(T, int) - Method in class org.apache.cassandra.io.ForwardingVersionedSerializer
-
- serializedSize(T) - Method in interface org.apache.cassandra.io.ISerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(IndexInfo) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
-
- serializedSize(Version, CompactionMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serializedSize(Version, T) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Calculate and return serialized size.
- serializedSize(Version, StatsMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serializedSize(Version, ValidationMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
-
- serializedSize(PingMessage, int) - Method in class org.apache.cassandra.net.PingMessage.PingMessageSerializer
-
- serializedSize(AnticompactionRequest, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- serializedSize(CleanupMessage, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- serializedSize(PrepareMessage, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
-
- serializedSize(RepairMessage, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serializedSize(SnapshotMessage, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- serializedSize(SyncRequest, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serializedSize(ValidationRequest, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serializedSize(NodePair, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serializedSize(IndexMetadata, int) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
-
- serializedSize(Collection<Mutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serializedSize(ProtocolVersion) - Method in class org.apache.cassandra.service.pager.PagingState
-
- serializedSize(Commit, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serializedSize(StreamRequest, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serializedSize(StreamSummary, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
-
- serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- serializedSize() - Method in class org.apache.cassandra.utils.BloomFilter
-
- serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serializedSize(EstimatedHistogram) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serializedSize() - Method in interface org.apache.cassandra.utils.IFilter
-
- serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serializedSize(MerkleTree, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serializedSize(MerkleTrees, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
-
- serializedSize() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serializedSize() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serializedSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serializedSize(StreamingHistogram) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializedSizeAsLegacyPartition(ReadCommand, UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- serializedSizeEndOfPartition() - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serializedSizeForMessaging(SerializationHeader, ColumnFilter, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
-
- serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- serializedSizeWithLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- serializedSizeWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- serializedSizeWithVIntLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- serializedSubsetSize(Collection<ColumnDefinition>, 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
-
- serializeForCache(RowIndexEntry<T>, DataOutputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- serializeForCache(DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry
-
- serializeForCache(RowIndexEntry<IndexInfo>, DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializeForMessaging(SerializationHeader, ColumnFilter, DataOutputPlus, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
-
- serializeForNativeProtocol(Iterator<Cell>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- serializeForNativeProtocol(Iterator<Cell>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UserType
-
- serializeForSSTable(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Serialize the specified type into the specified DataOutputStream
instance in the format suited for SSTables.
- 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
-
- serializeOffsets(DataOutputBuffer, int[], int) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializeOverflowCollisions(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
-
- serializePartitionKey(ClusteringPrefix) - Static method in class org.apache.cassandra.config.CFMetaData
-
- serializer - Static variable in class org.apache.cassandra.batchlog.Batch
-
- serializer - Static variable in class org.apache.cassandra.config.CFMetaData
-
- Serializer() - Constructor for class org.apache.cassandra.config.CFMetaData.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
- Serializer() - Constructor for class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.aggregation.GroupingState
-
- Serializer() - Constructor for class org.apache.cassandra.db.aggregation.GroupingState.Serializer
-
- serializer - Static variable in interface org.apache.cassandra.db.Clustering
-
- Serializer() - Constructor for class org.apache.cassandra.db.Clustering.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- Serializer() - Constructor for class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
-
- serializer - Static variable in interface org.apache.cassandra.db.ClusteringPrefix
-
- Serializer() - Constructor for class org.apache.cassandra.db.ClusteringPrefix.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.Columns
-
- Serializer() - Constructor for class org.apache.cassandra.db.Columns.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- serializer(ISerializer<T>) - Static method in class org.apache.cassandra.db.commitlog.IntervalSet
-
- serializer - Static variable in class org.apache.cassandra.db.CounterMutation
-
- serializer - Static variable in class org.apache.cassandra.db.DataRange
-
- Serializer() - Constructor for class org.apache.cassandra.db.DataRange.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.DeletionTime
-
- Serializer() - Constructor for class org.apache.cassandra.db.DeletionTime.Serializer
-
- serializer - Static variable in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnFilter
-
- Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnFilter.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSubselection
-
- Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.filter.DataLimits
-
- Serializer() - Constructor for class org.apache.cassandra.db.filter.DataLimits.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.filter.RowFilter
-
- Serializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.Serializer
-
- serializer - Variable in class org.apache.cassandra.db.marshal.ListType
-
- serializer - Static variable in class org.apache.cassandra.db.Mutation
-
- serializer - Static variable in interface org.apache.cassandra.db.PartitionPosition
-
- serializer - Static variable in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- Serializer() - Constructor for class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
-
- serializer() - Method in class org.apache.cassandra.db.RangeSliceVerbHandler
-
- serializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- serializer() - Method in class org.apache.cassandra.db.ReadCommandVerbHandler
-
- serializer - Static variable in class org.apache.cassandra.db.ReadResponse
-
- Serializer(CFMetaData, Version, SerializationHeader) - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.rows.Cell
-
- serializer - Static variable in class org.apache.cassandra.db.rows.EncodingStats
-
- Serializer() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
-
- serializer - Static variable in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serializer - Static variable in class org.apache.cassandra.db.SerializationHeader
-
- Serializer() - Constructor for class org.apache.cassandra.db.SerializationHeader.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.Slice
-
- Serializer() - Constructor for class org.apache.cassandra.db.Slice.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.Slices
-
- Serializer() - Constructor for class org.apache.cassandra.db.Slices.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
-
- serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Truncation
-
- serializer - Static variable in class org.apache.cassandra.db.WriteResponse
-
- Serializer() - Constructor for class org.apache.cassandra.db.WriteResponse.Serializer
-
- serializer - Static variable in class org.apache.cassandra.dht.Token
-
- serializer - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- serializer - Static variable in class org.apache.cassandra.gms.EndpointState
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigest
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck2
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestSyn
-
- serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- serializer - Static variable in class org.apache.cassandra.hints.Hint
-
- serializer - Static variable in class org.apache.cassandra.hints.HintMessage
-
- Serializer() - Constructor for class org.apache.cassandra.hints.HintMessage.Serializer
-
- serializer - Static variable in class org.apache.cassandra.hints.HintResponse
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- Serializer(Version, ISerializer<ClusteringPrefix>) - Constructor for class org.apache.cassandra.io.sstable.IndexInfo.Serializer
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- serializer - Variable in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- serializer - Variable in class org.apache.cassandra.net.CallbackInfo
-
- serializer - Variable in class org.apache.cassandra.net.MessageOut
-
- serializer - Static variable in class org.apache.cassandra.net.PingMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.CleanupMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SnapshotMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.NodePair
-
- serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
-
- serializer - Static variable in class org.apache.cassandra.schema.CompressionParams
-
- serializer - Static variable in class org.apache.cassandra.schema.IndexMetadata
-
- Serializer() - Constructor for class org.apache.cassandra.schema.IndexMetadata.Serializer
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.KeepAliveMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- serializer - Static variable in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamSummary
-
- serializer - Static variable in class org.apache.cassandra.utils.BooleanSerializer
-
- serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
-
- serializer(ISerializer<C>, ISerializer<D>, Constructor<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
-
- serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- serializer - Static variable in class org.apache.cassandra.utils.MerkleTrees
-
- serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
-
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
-
- serializerForIntraNode() - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
-
- serializers() - Method in class org.apache.cassandra.config.CFMetaData
-
- Serializers - Class in org.apache.cassandra.db
-
Holds references on serializers that depend on the table definition.
- Serializers(CFMetaData) - Constructor for class org.apache.cassandra.db.Serializers
-
- 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, SerializationHeader, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- serializeSubset(Collection<ColumnDefinition>, Columns, DataOutputPlus) - Method in class org.apache.cassandra.db.Columns.Serializer
-
If both ends have a pre-shared superset of the columns we are serializing, we can send them much
more efficiently.
- serializeValues(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- serializeValues(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- serializeValues(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- serializeValues(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- SerializingCache<K,V> - Class in org.apache.cassandra.cache
-
Serializes cache values off-heap.
- SerializingCacheProvider - Class in org.apache.cassandra.cache
-
- SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
-
- serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
-
- serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- Server - Class in org.apache.cassandra.transport
-
- Server.AbstractSecureIntializer - Class in org.apache.cassandra.transport
-
- Server.Builder - Class in org.apache.cassandra.transport
-
- Server.ConnectionTracker - Class in org.apache.cassandra.transport
-
- Server.EndpointPayloadTracker - Class in org.apache.cassandra.transport
-
- SERVER_DEFAULT - Static variable in interface org.apache.cassandra.transport.ProtocolVersionLimit
-
- server_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- ServerConnection - Class in org.apache.cassandra.transport
-
- ServerConnection(Channel, ProtocolVersion, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
-
- serverEncOptions - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- ServerEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- ServerError - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- session - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- session - Variable in class org.apache.cassandra.streaming.StreamReader
-
- session - Variable in class org.apache.cassandra.streaming.StreamTask
-
StreamSession that this task belongs
- session - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SESSION_FAILED_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- SESSION_SUCCESS_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- SessionCompleteEvent(StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- SessionCompleteEventCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionCompleteEventCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- sessionFailed() - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.SESSION_FAILED
message.
- SessionFailedMessage - Class in org.apache.cassandra.streaming.messages
-
- SessionFailedMessage() - Constructor for class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
RepairSession id
- sessionId - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- sessionId - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.SessionInfo
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- sessionIndex() - Method in class org.apache.cassandra.streaming.StreamSession
-
- SessionInfo - Class in org.apache.cassandra.streaming
-
Stream session info.
- SessionInfo(InetAddress, int, InetAddress, Collection<StreamSummary>, Collection<StreamSummary>, StreamSession.State) - Constructor for class org.apache.cassandra.streaming.SessionInfo
-
- SessionInfoCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- SessionPreparedEvent(UUID, SessionInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- sessions - Variable in class org.apache.cassandra.streaming.StreamState
-
- SESSIONS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
-
- sessions - Variable in class org.apache.cassandra.tracing.Tracing
-
- set(T) - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
-
Before a task has been run, this will be called with the value from the thread that scheduled the task, and after
the task is finished, the value that was previously retrieved from this thread is restored.
- set(ExecutorLocals) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
- set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- set(ClientWarn.State) - Method in class org.apache.cassandra.service.ClientWarn
-
- set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- set(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- set(T) - Method in class org.apache.cassandra.utils.DefaultValue
-
- Set() - Constructor for class org.apache.cassandra.utils.IntegerInterval.Set
-
- set(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
Sets the bit at the specified index.
- set(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long, byte) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set(T) - Method in class org.apache.cassandra.utils.Wrapped
-
- set(boolean) - Method in class org.apache.cassandra.utils.WrappedBoolean
-
- set(int) - Method in class org.apache.cassandra.utils.WrappedInt
-
- set_cql_version(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- setAllTermsToLowerCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setAllTermsToUpperCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setAnyNodeOn30(boolean) - Method in class org.apache.cassandra.gms.Gossiper
-
- setAttachment(ByteBuffer, Object) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setAuthenticator(IAuthenticator) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setAuthorizer(IAuthorizer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setAutoSnapshot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBackPressureEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBackPressureEnabled(boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- setBackPressureEnabled(boolean) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Enable/Disable back-pressure
- setBackPressureStrategy(BackPressureStrategy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBatchSizeFailThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBatchSizeFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setBatchSizeFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for rejecting queries due to a large batch size
- setBatchSizeWarnThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setBoundVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- setBoundVariables(VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- 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!!
- setBroadcastRpcAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setByte(long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setByte(long, byte) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setByte(long, int, byte) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setByteBuffer(ByteBuffer, long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- setByteBuffer(ByteBuffer, long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.Memory
-
- setBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from buffer to Memory
- setBytes(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
Transfers count bytes from buffer to Memory
- setBytes(long, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(byte[], int, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setCacheCapacities(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetCacheCapacity - Class in org.apache.cassandra.tools.nodetool
-
- SetCacheCapacity() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheCapacity
-
- 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
-
- setCallbackForTests(int, CallbackInfo) - Method in class org.apache.cassandra.net.MessagingService
-
- setCapacity(long) - Method in interface org.apache.cassandra.cache.CacheSize
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.ChunkCache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.SerializingCache
-
- setCasContentionTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCasContentionTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setCasContentionTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setCasContentionTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setCasContentionTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setCDCEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCDCSpaceInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCDCState(CommitLogSegment.CDCState) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Change the current cdcState on this CommitLogSegment.
- setCheckForDuplicateRowsDuringCompaction(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCheckForDuplicateRowsDuringReads(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setColumnFamily(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
-
- setColumnIndexCacheSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setColumnIndexSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitFailurePolicy(Config.CommitFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogLocation(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogMaxCompressionBuffersPerPool(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSegmentSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSync(Config.CommitLogSync) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSyncBatchWindow(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSyncPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompactionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction parameters locally for this node
Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
- setCompactionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction parameters locally for this node
Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
- setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
Set the compaction threshold
- SetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
-
- SetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
-
- setCompactionThresholds(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionThresholds(int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum and maximum number of SSTables in queue before compaction kicks off
- setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
-
- setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.CFProperties
-
- setComplexDeletionTime(ColumnDefinition) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- setComplexDeletionTimeForOverwrite(ColumnDefinition) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- setCompressionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompressionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set the compression parameters
- setCompressionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompressionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- setCompressor(FrameCompressor) - Method in class org.apache.cassandra.transport.Connection
-
- 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
-
- setConnectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Allows user to resize core pool size of the thread pool.
- setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCounterCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterWriteRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setCounterWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setCounterWriteRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setCounterWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCrcCheckChance(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCrcCheckChance(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set new crc check chance
- setCrcCheckChance(double) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Set the value of CRC check chance.
- setCrcCheckChance(double) - Method in class org.apache.cassandra.schema.CompressionParams
-
- setCredentialsCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCredentialsUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCredentialsValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- setCustomPayload(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.transport.Message
-
- setDelegate(MBeanWrapper) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
-
- setDeleteSourceOnSuccess(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setDigestVersion(int) - Method in class org.apache.cassandra.db.ReadCommand
-
Sets the digest version, for when digest for that command is requested.
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
Indicate the memory and resources owned by this allocator are no longer referenced,
and can be reclaimed/reused.
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- setDiscarding(OpOrder.Barrier, AtomicReference<CommitLogPosition>) - Method in class org.apache.cassandra.db.Memtable
-
- setDiscarding() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
Mark this allocator reclaiming; this will permit any outstanding allocations to temporarily
overshoot the maximum memory limit so that flushing can begin immediately
- setDiskAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDiskFailurePolicy(Config.DiskFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicBadnessThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicResetInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicUpdateInterval(int) - Method in class org.apache.cassandra.service.StorageService
-
- setDynamicUpdateInterval(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- SetElement(Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetElement
-
- setEnableDropCompactStorage(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEnableMaterializedViews(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEnableSASIIndexes(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEncryptionContext(EncryptionContext) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEventHandler(SimpleClient.EventHandler) - Method in class org.apache.cassandra.transport.SimpleClient
-
- SetField(FieldIdentifier, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetField
-
- setForceNewPreparedStatementBehaviour(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setForSlice(Slice) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- setFSErrorHandler(FSErrorHandler) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- setGlobalPrefix(String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- setGossipTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
- setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- setHintedHandoffEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
-
- setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setHintedHandoffThrottleInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.service.StorageService
-
- setHintedHandoffThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the hinted handoff throttle in kb per second, per delivery thread.
- setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetHintedHandoffThrottleInKB - Class in org.apache.cassandra.tools.nodetool
-
- SetHintedHandoffThrottleInKB() - Constructor for class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
-
- setHintsCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- SetHostStat - Class in org.apache.cassandra.tools.nodetool
-
- SetHostStat(boolean) - Constructor for class org.apache.cassandra.tools.nodetool.SetHostStat
-
- setIgnoreHosts(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Set the hosts to ignore as comma delimited values.
- setIgnoreHosts(Configuration, String...) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Set the hosts to ignore.
- setIgnoreStopTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setIncrementalBackupsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- setIncrementalBackupsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setIndex(String, boolean) - Method in class org.apache.cassandra.cql3.IndexName
-
- setIndexAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setInitialized() - Static method in class org.apache.cassandra.db.Keyspace
-
- setInputColumnFamily(Configuration, String, String, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumns(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL columns for the input of this job.
- setInputCoreConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputCQLPageRowSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL query Limit for the input of this job.
- setInputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputMaxConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputMaxSimultReqPerConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeAuthProvider(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeKeepAlive(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativePort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReadConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReceiveBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReuseAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSendBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSolinger(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLCipherSuites(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLKeystorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLKeystorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLTruststorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLTruststorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeTcpNodelay(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputRange(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, String, String, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputSlicePredicate(Configuration, SlicePredicate) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the predicate that determines what columns will be selected from each row.
- setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the size of the input split.
- setInputSplitSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the size of the input split.
- setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL user defined where clauses for the input of this job.
- setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- setInt(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setInterDCStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
-
- setInterDCStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setInterDCStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setInterDCStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setInternodeAuthenticator(IInternodeAuthenticator) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIsShutdownUnsafeForTests(boolean) - Method in class org.apache.cassandra.service.StorageService
-
for in-jvm dtest use - forces isShutdown to be set to whatever passed in.
- setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyspace(String) - Method in class org.apache.cassandra.cql3.UTName
-
- setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
-
- SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- setKeyspaceMetadata(KeyspaceMetadata) - Method in class org.apache.cassandra.config.Schema
-
Update (or insert) new keyspace definition
- setLast(String, FilterPipelineTask<K, V>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
-
- setLastProcessedMessageAt(long) - Method in class org.apache.cassandra.gms.Gossiper
-
- setLeft(Operation.Builder) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
-
- setLocalCompressionParams(CompressionParams) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- setLoggingLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
set the logging level at runtime
If both classQualifer and level are empty/null, it will reload the configuration to reset.
If classQualifer is not empty but level is empty/null, it will set the level to null for the defined classQualifer
If level cannot be parsed, then the level will be defaulted to DEBUG
The logback configuration should have < jmxConfigurator />
set
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetLoggingLevel - Class in org.apache.cassandra.tools.nodetool
-
- SetLoggingLevel() - Constructor for class org.apache.cassandra.tools.nodetool.SetLoggingLevel
-
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
-
- setLoggingLevel(String, String) - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
-
Changes the given logger to the given log level.
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.utils.logging.NoOpFallbackLoggingSupport
-
- setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- setLong(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setLower(Expression.Bound) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- setLowerCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- setMaxDataAge(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- setMaxEntries(int) - Method in class org.apache.cassandra.auth.AuthCache
-
- setMaxEntries(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- setMaxHintsInProgress(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintsInProgress(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaxHintWindow(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setMaxHintWindow(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintWindow(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaximumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setMaximumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum number of sstables in queue before compaction kicks off
- setMaximumCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Allows user to resize maximum size of the thread pool.
- setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the validator thread pool.
- setMaxTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setMaxValueSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setMemoryPoolCapacityInMB(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- setMemoryPoolCapacityInMB(long) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- setMetadata(KeyspaceMetadata) - Method in class org.apache.cassandra.db.Keyspace
-
- setMinimumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setMinimumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the minimum number of sstables in queue before compaction kicks off
- setMinTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setMonitoringTime(long, boolean, long, long) - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
This setter is ugly but the construction chain to ReadCommand
is too complex, it would require passing new parameters to all serializers
or specializing the serializers to accept these message properties.
- setMovingModeUnsafe() - Method in class org.apache.cassandra.service.StorageService
-
- setName(String, boolean) - Method in class org.apache.cassandra.cql3.RoleName
-
- setNativeTransportMaxConcurrentConnections(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setNativeTransportMaxConcurrentConnections(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setNativeTransportMaxConcurrentConnections(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setNativeTransportMaxConcurrentConnectionsPerIp(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setNativeTransportMaxConcurrentConnectionsPerIp(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setNativeTransportMaxConcurrentRequestsInBytes(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - 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
-
- setNewLocalCompactionStrategy(CompactionParams) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- setNoCompactMode() - Method in class org.apache.cassandra.service.ClientState
-
- setNormalModeUnsafe() - Method in class org.apache.cassandra.service.StorageService
-
Only used in jvm dtest when not using GOSSIP.
- setOp(Expression.Op) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
-
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
-
- setOpenResult(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
-
- setOption(IRoleManager.Option, Object) - Method in class org.apache.cassandra.auth.RoleOptions
-
Set a value for a specific option.
- setOptions(Map<String, String>) - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
Sets an implementation defined set of options.
- setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- setOrdering(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.CFProperties
-
- setOrListToJsonString(ByteBuffer, AbstractType, ProtocolVersion) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- setOrMapLiteral(Term.Raw) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- setOrMapLiteral(Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- setOtcBacklogExpirationInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setOtcBacklogExpirationInterval(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setOtcBacklogExpirationInterval(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setOtcCoalescingEnoughCoalescedMessages(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- setOutput(Output) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL prepared statement for the output of this job.
- setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace for the output of this job.
- setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputLocalDCOnly(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOverrideLoadConfig(Supplier<Config>) - Static method in class org.apache.cassandra.config.Config
-
- setPartitionerUnsafe(IPartitioner) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPartitionerUnsafe(IPartitioner) - Method in class org.apache.cassandra.service.StorageService
-
- setPermissionsCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPermissionsUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPermissionsValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPhiConvictThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPhiConvictThreshold(double) - Method in class org.apache.cassandra.gms.FailureDetector
-
- setPhiConvictThreshold(double) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- setPosition(long) - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
-
- setPostFlushListener(Runnable) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- setPreviousReleaseVersionString(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- setQuickResolver(BTree.Builder.QuickResolver<V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- setRangeRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRangeRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRangeRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setRangeRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setRangeRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setRate(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Sets the rate for the rate limiter.
- setReadConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setReadRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setReadRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setReadRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setReadRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setReadRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- 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
-
- setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- setRepairSessionMaxTreeDepth(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRepairSessionMaxTreeDepth(int) - Method in class org.apache.cassandra.service.StorageService
-
- setRepairSessionMaxTreeDepth(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- setRight(Operation.Builder) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
-
- setRoleManager(IRoleManager) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRolesCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRolesUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRolesValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRowCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRowCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheSizeInMB(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRpcReady(boolean) - Method in class org.apache.cassandra.service.StorageService
-
Set the RPC status.
- setRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- Sets - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for sets.
- Sets.Adder - Class in org.apache.cassandra.cql3
-
- Sets.DelayedValue - Class in org.apache.cassandra.cql3
-
- Sets.Discarder - Class in org.apache.cassandra.cql3
-
- Sets.ElementDiscarder - Class in org.apache.cassandra.cql3
-
- Sets.Literal - Class in org.apache.cassandra.cql3
-
- Sets.Marker - Class in org.apache.cassandra.cql3
-
- Sets.Setter - Class in org.apache.cassandra.cql3
-
- Sets.Value - Class in org.apache.cassandra.cql3
-
- SetSerializer<T> - Class in org.apache.cassandra.serializers
-
- setSeverity(double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- setSeverity(double) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
Setting a Severity allows operators to inject preference information into the Dynamic Snitch
replica selection.
- setShort(long, short) - Method in class org.apache.cassandra.io.util.Memory
-
- setShort(long, short) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- setSkipStatic() - Method in class org.apache.cassandra.db.UnfilteredDeserializer.OldFormatDeserializer
-
- setSnapshotOnDuplicateRowDetection(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setSourceFrame(Frame) - Method in class org.apache.cassandra.transport.Message
-
- setSSTablePreempiveOpenIntervalInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setStatus(TaskAttemptContext, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke setStatus() on TaskAttemptContext.
- setStatus(String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- setStemTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- setStreamFactory(AutoSavingCache.IStreamFactory) - Static method in class org.apache.cassandra.cache.AutoSavingCache
-
- setStreamId(int) - Method in class org.apache.cassandra.transport.Message
-
- setStreamingSocketTimeout(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setStreamingSocketTimeout(int) - Method in class org.apache.cassandra.service.StorageService
-
- setStreamingSocketTimeout(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetStreamThroughput
-
- setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setSupportsBackPressure(boolean) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- setTableAlias(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setTableInsertStatement(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- setTableSchema(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.UserTypes.Setter
-
- SetterByField(ColumnDefinition, FieldIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.UserTypes.SetterByField
-
- SetterByIndex(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- SetterByKey(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
-
- setThriftFramedTransportSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setThrowOnOverload(boolean) - Method in class org.apache.cassandra.transport.Connection
-
- setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Sets the socket timeout
- 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
-
- setToBlock(int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- setTombstoneFailureThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTombstoneFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setTombstoneFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for abandoning queries with many tombstones
- setTombstoneWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTombstoneWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setTombstoneWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for warning queries with many tombstones
- setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
-
- setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Enables/Disables tracing for the whole system.
- setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetTraceProbability - Class in org.apache.cassandra.tools.nodetool
-
- SetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.SetTraceProbability
-
- setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
-
- setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- setTruncateRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTruncateRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setTruncateRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setTruncateRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setTruncateRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- SetType<T> - Class in org.apache.cassandra.db.marshal
-
- SetType(AbstractType<T>, boolean) - Constructor for class org.apache.cassandra.db.marshal.SetType
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Setup is called once upon system startup to initialize the IAuthorizer.
- setup() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Hook to perform implementation specific initialization, called once upon system startup.
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- setupCompleted() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- setUpdateInterval(int) - Method in class org.apache.cassandra.auth.AuthCache
-
- setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- setupOnline() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- setUpper(Expression.Bound) - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- setUpperCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setUserDefinedFunctionFailTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setUserDefinedFunctionWarnTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setUserFunctionTimeoutPolicy(Config.UserFunctionTimeoutPolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setValidity(int) - Method in class org.apache.cassandra.auth.AuthCache
-
- setValidity(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
-
- SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
-
- setValue(ByteBuffer) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
-
- setValue(ColumnDefinition, CellPath, ByteBuffer) - Method in class org.apache.cassandra.db.rows.BTreeRow
-
- setVersion(InetAddress, int) - Method in class org.apache.cassandra.net.MessagingService
-
- setViewBuilt(String, String, boolean) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setViewBuiltReplicated(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setViewRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setViewRemoved(String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- setWarnings(List<String>) - Method in class org.apache.cassandra.transport.Message.Response
-
- setWriteConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setWriteRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setWriteRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
-
- setWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- shadowable(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
-
Deprecated.
- shadowSources(DecoratedKey, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- SHARED - Static variable in class org.apache.cassandra.concurrent.SharedExecutorPool
-
- SHARED_HEADER_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- SharedCloseable - Interface in org.apache.cassandra.utils.concurrent
-
A simple extension of AutoCloseable, that represents a resource that can be utilised in multiple locations,
each managing their own closure of the resource, so that when the last such instance is closed all are.
- SharedCloseableImpl - Class in org.apache.cassandra.utils.concurrent
-
A simple abstract implementation of SharedCloseable
- SharedCloseableImpl(RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- SharedCloseableImpl(SharedCloseableImpl) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- sharedCopy() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.FileHandle
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.MmappedRegions
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- sharedCopy() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- sharedCopy() - Method in class org.apache.cassandra.utils.BloomFilter
-
- sharedCopy() - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
-
- 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
-
- sHeader - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- shorthandColumnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- shorthandColumnOperation(List<Pair<ColumnDefinition.Raw, Operation.RawUpdate>>, ColumnDefinition.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- shortReadProtectionRequests - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- ShortSerializer - Class in org.apache.cassandra.serializers
-
- ShortSerializer() - Constructor for class org.apache.cassandra.serializers.ShortSerializer
-
- ShortType - Class in org.apache.cassandra.db.marshal
-
- shouldBeEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- shouldBeEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- shouldBuildBlocking() - Method in interface org.apache.cassandra.index.Index
-
Return true if this index can be built or rebuilt when the index manager determines it is necessary.
- shouldBuildBlocking() - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- shouldBuildBlocking() - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- shouldCheckCrc() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
-
- shouldClearLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- shouldEncrypt(InetAddress) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- shouldHint() - Method in class org.apache.cassandra.net.CallbackInfo
-
- shouldHint() - Method in class org.apache.cassandra.net.WriteCallbackInfo
-
- shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
-
- shouldIgnoreStopTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- shouldInclude(SSTableReader) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
Whether the provided sstable may contain data that is selected by this filter (based on the sstable metadata).
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- shouldInclude(InetAddress) - Method in interface org.apache.cassandra.dht.RangeStreamer.ISourceFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- shouldListenOnBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- shouldLogAverage - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- shouldLowerCaseOutput() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- shouldLowerCaseTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- shouldPullFromEndpoint(InetAddress) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- shouldPullImmediately(InetAddress, UUID) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- shouldPullSchema(UUID) - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- shouldPurge(long, int) - Method in interface org.apache.cassandra.db.DeletionPurger
-
- shouldPurge(DeletionTime) - Method in interface org.apache.cassandra.db.DeletionPurger
-
- shouldPurge(LivenessInfo, int) - Method in interface org.apache.cassandra.db.DeletionPurger
-
- shouldSkipSegmentOnError(CommitLogReadHandler.CommitLogReadException) - Method in interface org.apache.cassandra.db.commitlog.CommitLogReadHandler
-
Handle an error during segment read, signaling whether or not you want the reader to skip the remainder of the
current segment on error.
- shouldSkipSegmentOnError(CommitLogReadHandler.CommitLogReadException) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- shouldStemTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- shouldUpperCaseOutput() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
-
- shouldUpperCaseTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- shuffle(List<?>) - Method in class org.apache.cassandra.batchlog.BatchlogManager.EndpointFilter
-
- shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Initiates the shutdown process for the management thread.
- shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
Initiates the shutdown process for the management thread.
- shutdown() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Releases any resources if this strategy is shutdown (when the CFS is reloaded after a schema change).
- shutdown() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
- SHUTDOWN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- shutdown(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- shutdown() - Method in class org.apache.cassandra.net.MessagingService
-
Wait for callbacks and don't allow any more to be created (since they could require writing hints)
- shutdown(boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- shutdown() - Static method in class org.apache.cassandra.transport.Message.Dispatcher
-
- shutdown(Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdown(boolean, Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdown(ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.concurrent.ScheduledExecutors
-
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
-
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.concurrent.StageManager
-
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.streaming.StreamCoordinator
-
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.streaming.StreamSession
-
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- shutdownAndWait(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.utils.memory.MemtablePool
-
- shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Shuts down the threads used by the commit log, blocking until completion.
- shutdownBlocking() - Method in class org.apache.cassandra.hints.HintsService
-
Gracefully and blockingly shut down the service.
- shutdownBlocking(long, TimeUnit) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- shutdownBlocking() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- shutdownExecutor(long, TimeUnit) - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
-
- shutdownExecutorsAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- shutdownFlushExecutor() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- shutdownLocalCleaner(long, TimeUnit) - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
-
This method shuts down all registered stages.
- shutdownNow(Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownNow(ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownNowAndWait(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownNowAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
-
- shutdownPostFlushExecutor() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- shutdownReferenceReaper(long, TimeUnit) - Static method in class org.apache.cassandra.utils.concurrent.Ref
-
- shutdownServer() - Method in class org.apache.cassandra.service.StorageService
-
- SigarLibrary - Class in org.apache.cassandra.utils
-
- signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- signal() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- signal() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- signal() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal one waiting thread
- signalAll() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- signalAll() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal all waiting threads
- simple(int) - Static method in class org.apache.cassandra.schema.KeyspaceParams
-
- Simple(BiFunction<V, V, V>) - Constructor for class org.apache.cassandra.utils.btree.UpdateFunction.Simple
-
- simpleBuilder(String, DecoratedKey) - Static method in class org.apache.cassandra.db.Mutation
-
Creates a new simple mutuation builder.
- simpleBuilder(CFMetaData, Object...) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates a new simple partition update builder.
- simpleBuilder(CFMetaData, Object...) - Static method in class org.apache.cassandra.db.rows.Rows
-
Creates a new simple row builder.
- SimpleBuilders - Class in org.apache.cassandra.db
-
- SimpleBuilders.MutationBuilder - Class in org.apache.cassandra.db
-
- SimpleBuilders.PartitionUpdateBuilder - Class in org.apache.cassandra.db
-
- SimpleBuilders.RowBuilder - Class in org.apache.cassandra.db
-
- SimpleCachedBufferPool - Class in org.apache.cassandra.io.util
-
A very simple Bytebuffer pool with a fixed allocation size and a cached max allocation count.
- SimpleCachedBufferPool(int, int, BufferType) - Constructor for class org.apache.cassandra.io.util.SimpleCachedBufferPool
-
- SimpleClient - Class in org.apache.cassandra.transport
-
- SimpleClient(String, int, ProtocolVersion, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int, ProtocolVersion) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int, ProtocolVersion, boolean, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient.EventHandler - Interface in org.apache.cassandra.transport
-
- SimpleClient.SimpleEventHandler - Class in org.apache.cassandra.transport
-
- 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.ColumnCondition.Raw
-
A condition on a column.
- SimpleCondition - Class in org.apache.cassandra.utils.concurrent
-
- SimpleCondition() - Constructor for class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- SimpleDateSerializer - Class in org.apache.cassandra.serializers
-
- SimpleDateSerializer() - Constructor for class org.apache.cassandra.serializers.SimpleDateSerializer
-
- SimpleDateType - Class in org.apache.cassandra.db.marshal
-
- SimpleEventHandler() - Constructor for class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
-
- simpleIdx(ColumnDefinition) - 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.ColumnCondition.Raw
-
An IN condition on a column.
- simpleInCondition(AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a column with a single marker.
- simpleIndexOn(ColumnDefinition.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
-
- simpleIterator(FileDataInput, DecoratedKey, RowIndexEntry, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- simpleIterator(FileDataInput, DecoratedKey, RowIndexEntry, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SimpleLeafEntry(long, long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
-
- simpleMapping(Iterable<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- SimpleSeedProvider - Class in org.apache.cassandra.locator
-
- SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
-
- SimpleSelector - Class in org.apache.cassandra.cql3.selection
-
- SimpleSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that treats Strategy order as proximity,
allowing non-read-repaired reads to prefer a single endpoint, which improves
cache locality.
- SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
-
- 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
-
- simpleTransient(int) - Static method in class org.apache.cassandra.schema.KeyspaceParams
-
- singleCellRow(Clustering, Cell) - Static method in class org.apache.cassandra.db.rows.BTreeRow
-
- singleColumnInValues() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- singleColumnInValues() - Method in class org.apache.cassandra.cql3.CqlParser
-
- SingleColumnRelation - Class in org.apache.cassandra.cql3
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- SingleColumnRelation(ColumnDefinition.Raw, Term.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRelation(ColumnDefinition.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- SingleColumnRestriction.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
-
- SingleColumnRestriction.SuperColumnKeyEQRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.SuperColumnKeyINRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.SuperColumnKeyINRestrictionWithMarkers - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.SuperColumnKeyINRestrictionWithValues - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.SuperColumnKeySliceRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.SuperColumnMultiEQRestriction - Class in org.apache.cassandra.cql3.restrictions
-
Super Column Compatibiltiy
- SingleColumnRestriction.SuperColumnMultiSliceRestriction - 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(SinglePartitionReadCommand, 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.Group - Class in org.apache.cassandra.db
-
Groups multiple single partition read commands.
- SinglePartitionSliceBuilder(ColumnFamilyStore, DecoratedKey) - Constructor for class org.apache.cassandra.db.AbstractReadCommandBuilder.SinglePartitionSliceBuilder
-
- SingleRestriction - Interface in org.apache.cassandra.cql3.restrictions
-
A single restriction/clause on one or multiple column.
- singleRowUpdate(CFMetaData, DecoratedKey, Row, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates an immutable partition update that contains a single row update.
- singleRowUpdate(CFMetaData, DecoratedKey, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates an immutable partition update that contains a single row update.
- singleRowUpdate(CFMetaData, ByteBuffer, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates an immutable partition update that contains a single row update.
- singleton(Unfiltered, CFMetaData, DecoratedKey, DeletionTime, PartitionColumns, Row, boolean, EncodingStats) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
- singleton(Object) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- singletonIterator(RowIterator) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
-
- SingletonUnfilteredPartitionIterator - Class in org.apache.cassandra.db.partitions
-
- SingletonUnfilteredPartitionIterator(UnfilteredRowIterator, boolean) - Constructor for class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
-
- 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.ChunkCache
-
- size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- 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.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.cql3.VariableSpecifications
-
- size() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
-
- 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.LegacyLayout.LegacyRangeTombstoneList
-
- size() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- size - Variable in class org.apache.cassandra.db.MultiCBuilder
-
The number of clustering elements that have been added.
- size() - Method in class org.apache.cassandra.db.NativeClustering
-
- size() - Method in class org.apache.cassandra.db.PartitionColumns
-
Returns the total number of static and regular columns.
- size() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- 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.view.TableViews
-
- size(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- size(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- size(Token) - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- size(Token) - Method in class org.apache.cassandra.dht.Token
-
Returns a measure for the token space covered between this token and next.
- size - Variable in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
-
- size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- size() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- size - Variable in class org.apache.cassandra.io.util.Memory
-
- size() - Method in class org.apache.cassandra.io.util.Memory
-
- size - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
-
Total size of buffer pools, in bytes
- size - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total size of cache, in bytes
- size - Variable in class org.apache.cassandra.metrics.CacheMissMetrics
-
Total size of cache, in bytes
- size() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Return the number of buckets where recorded values are stored.
- size() - Method in class org.apache.cassandra.schema.Indexes
-
- size() - Method in class org.apache.cassandra.schema.Tables
-
- size() - Method in class org.apache.cassandra.schema.Triggers
-
- size() - Method in class org.apache.cassandra.schema.Views
-
- size() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- size() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
-
- size() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- size(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- size() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- size() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- size() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- size() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- size() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- size - Variable in class org.apache.cassandra.utils.DirectorySizeCalculator
-
- size() - Method in class org.apache.cassandra.utils.DynamicList
-
- size() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- size() - Method in class org.apache.cassandra.utils.LockedDynamicList
-
- size - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- size() - Method in class org.apache.cassandra.utils.MerkleTree
-
The number of distinct ranges contained in this tree.
- size() - Method in class org.apache.cassandra.utils.MerkleTrees
-
- size() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity of this set.
- size() - Method in class org.apache.cassandra.utils.SlidingTimeRate
-
- SIZE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- sizeComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SizeEstimatesRecorder - Class in org.apache.cassandra.db
-
A very simplistic/crude partition count/size estimator.
- sizeInBytes() - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
- sizeof(String) - Static method in class org.apache.cassandra.db.TypeSizes
-
assumes UTF8
- sizeof(boolean) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(byte) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(short) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(int) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(long) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(UUID) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeOf(AbstractType<?>) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
-
- sizeOf(String) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a String consumes
- sizeOfArray(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte array consumes
- sizeOfArray(long[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a long array consumes
- sizeOfArray(int[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory an int array consumes
- sizeOfArray(Object[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a reference array consumes itself only
- sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfBytesMap(Map<String, ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfCollectionSize(int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- sizeOfConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfEnumValue(T) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfInet(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfInetAddr(InetAddress) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfLongString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfReferenceArray(int) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a reference array consumes
- sizeOfString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringList(List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringMap(Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringToStringListMap(Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStructureOnHeap(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- sizeofUnsignedVInt(long) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- sizeOfValue(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(int) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeofVInt(long) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithLength(ByteBuffer) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithVIntLength(ByteBuffer) - Static method in class org.apache.cassandra.db.TypeSizes
-
- sizeOnHeapExcludingData(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- sizeOnHeapExcludingData(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- sizeOnHeapOf(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a ByteBuffer array consumes.
- sizeOnHeapOf(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte buffer consumes
- sizeOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- sizeOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- sizeRatio() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- sizeTieredOptions - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- skip(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
-
- skip(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
-
- skip(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- skip(DataInputPlus, Version) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skip(DataInputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
-
- skip(DataInputPlus) - Method in interface org.apache.cassandra.io.ISerializer
-
- skip(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
-
- skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Skips count
number of bytes in this InputStream.
- skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- skip(long) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- skip(long) - Method in class org.apache.cassandra.io.util.TrackedInputStream
-
- SKIP_SYNC - Static variable in class org.apache.cassandra.utils.SyncUtil
-
- skipBytes(int) - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
Always skips the requested number of bytes, unless EOF is reached
- skipBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- skipBytesFully(int) - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
- skipDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- skipForCache(DataInputPlus, Version) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- SkipListMemIndex - Class in org.apache.cassandra.index.sasi.memory
-
- SkipListMemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
-
- skipLocalDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- skipMarkerBody(DataInputPlus) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- skipNext() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
-
- skipNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer.OldFormatDeserializer
-
- skipNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Skips the next atom.
- 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, SerializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
- skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- skipTimestamp(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- skipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
When called, this iterators current position should
be skipped forwards until finding either:
1) an element equal to or bigger than next
2) the end of the iterator
- skipTTL(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
-
- skipValue(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- skipValues(DataInputPlus, ClusteringPrefix.Kind, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
-
- skipWithVIntLength(DataInputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- SlabAllocator - Class in org.apache.cassandra.utils.memory
-
+ * The SlabAllocator is a bump-the-pointer allocator that allocates
+ * large (1MB) global regions and then doles them out to threads that
+ * request smaller sized (up to 128kb) slices into the array.
- SlabPool - Class in org.apache.cassandra.utils.memory
-
- SlabPool(long, long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.SlabPool
-
- sleep(long, TimeUnit) - Method in class org.apache.cassandra.utils.SystemTimeSource
-
- sleep(long, TimeUnit) - Method in interface org.apache.cassandra.utils.TimeSource
-
Sleep for the given amount of time.
- sleepQuietly(long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- sleepUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.utils.SystemTimeSource
-
- sleepUninterruptibly(long, TimeUnit) - Method in interface org.apache.cassandra.utils.TimeSource
-
Sleep for the given amount of time uninterruptibly.
- slice - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- slice(ColumnDefinition, CellPath, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
-
- slice(ColumnDefinition, CellPath, CellPath) - Static method in class org.apache.cassandra.db.filter.ColumnSubselection
-
- Slice - Class in org.apache.cassandra.db
-
A slice represents the selection of a range of rows.
- slice(Object[], Comparator<? super K>, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Returns an Iterator over the entire tree
- slice(Object[], Comparator<? super K>, K, K, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- slice(Object[], Comparator<? super K>, K, boolean, K, boolean, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- Slice.Serializer - Class in org.apache.cassandra.db
-
- SliceRestriction(List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
-
- SliceRestriction(ColumnDefinition, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
-
- SliceRestriction(CFMetaData, List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
-
- slices - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- Slices - Class in org.apache.cassandra.db
-
Represents the selection of multiple range of rows within a partition.
- Slices() - Constructor for class org.apache.cassandra.db.Slices
-
- Slices.Builder - Class in org.apache.cassandra.db
-
Builder to create Slices
objects.
- Slices.InOrderTester - Interface in org.apache.cassandra.db
-
- Slices.Serializer - Class in org.apache.cassandra.db
-
- SlidingTimeRate - Class in org.apache.cassandra.utils
-
Concurrent rate computation over a sliding time window.
- SlidingTimeRate(TimeSource, long, long, TimeUnit) - Constructor for class org.apache.cassandra.utils.SlidingTimeRate
-
Creates a sliding rate whose time window is of the given size, with the given precision and time unit.
- slow_query_log_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- slowTimeout() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- slowTimeout() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- 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
-
- smallMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for small message TCP Connections
- smallMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for small message TCP Connections
- smallMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for small message TCP Connections
- smallMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- snappy() - Static method in class org.apache.cassandra.schema.CompressionParams
-
- snappy(Integer) - Static method in class org.apache.cassandra.schema.CompressionParams
-
- SnappyCompressor - Class in org.apache.cassandra.io.compress
-
- SnappyCompressor() - Constructor for class org.apache.cassandra.io.compress.SnappyCompressor
-
- snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Take a snap shot of this columnfamily store.
- snapshot(String, boolean) - 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, String, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
Take a snapshot of the specific column family, or the entire set of column families
if columnFamily is null with a given timestamp
- snapshot(String, String) - Method in class org.apache.cassandra.db.Keyspace
-
Take a snapshot of the specific column family, or the entire set of column families
if columnFamily is null with a given timestamp
- Snapshot - Class in org.apache.cassandra.tools.nodetool
-
- Snapshot() - Constructor for class org.apache.cassandra.tools.nodetool.Snapshot
-
- snapshot(SnapshotCommand, InetAddress) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
-
- snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
-
- SNAPSHOT_DROP_PREFIX - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshot_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_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
-
- SNAPSHOT_TRUNCATE_PREFIX - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- SnapshotCommand - Class in org.apache.cassandra.db
-
- SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
-
- snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
-
- SnapshotDeletingTask - Class in org.apache.cassandra.io.sstable
-
- SnapshotDetailsTabularData - Class in org.apache.cassandra.db
-
- SnapshotDetailsTabularData() - Constructor for class org.apache.cassandra.db.SnapshotDetailsTabularData
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Directories
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Keyspace
-
Check whether snapshots already exists for a given name.
- SnapshotMessage - Class in org.apache.cassandra.repair.messages
-
- SnapshotMessage(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage
-
- SnapshotMessage.SnapshotMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- SnapshotMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- snapshotOnDuplicateRowDetection() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- snapshotOnVersionChange() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Compare the release version in the system.local table with the one included in the distro.
- snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SnapshotTask - Class in org.apache.cassandra.repair
-
SnapshotTask is a task that sends snapshot request.
- SnapshotTask(RepairJobDesc, InetAddress) - Constructor for class org.apache.cassandra.repair.SnapshotTask
-
- SnapshotVerbHandler - Class in org.apache.cassandra.service
-
- SnapshotVerbHandler() - Constructor for class org.apache.cassandra.service.SnapshotVerbHandler
-
- snapshotWithoutFlush(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshotWithoutFlush(String, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- SNITCH_PROPERTIES_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
-
- SnitchProperties - Class in org.apache.cassandra.locator
-
- SnitchProperties() - Constructor for class org.apache.cassandra.locator.SnitchProperties
-
- SnitchProperties(Properties) - Constructor for class org.apache.cassandra.locator.SnitchProperties
-
- socket - Variable in class org.apache.cassandra.net.IncomingStreamingConnection
-
- socket - Variable in class org.apache.cassandra.transport.Server
-
- SOCKET_TIMEOUT - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- sort(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
- sort() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
- sort(long[], LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
-
- sort(long[], int, int, LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the List of node addresses, in-place, by proximity to the given address
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
This method will sort the List by proximity to the given address.
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- sorted() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Creates a CQLSSTableWriter that expects sorted inputs.
- SortedBiMultiValMap<K,V> - Class in org.apache.cassandra.utils
-
- SortedBiMultiValMap(SortedMap<K, V>, SortedSetMultimap<V, K>) - Constructor for class org.apache.cassandra.utils.SortedBiMultiValMap
-
- sortedBuilder() - Static method in class org.apache.cassandra.db.rows.BTreeRow
-
- sortedList() - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
Returns a sorted version of the list
method.
- sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- source - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- SOUTH_EAST_ASIAN_TYPE - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
Chars in class \p{Line_Break = Complex_Context} are from South East Asian
scripts (Thai, Lao, Myanmar, Khmer, etc.).
- 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
-
- specialStateTransition(int, IntStream) - Method in class org.apache.cassandra.cql3.Cql_Lexer.DFA55
-
- speculativeRetries - Variable in class org.apache.cassandra.metrics.TableMetrics
-
- speculativeRetries - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- speculativeRetry(SpeculativeRetryParam) - Method in class org.apache.cassandra.config.CFMetaData
-
- speculativeRetry(SpeculativeRetryParam) - Method in class org.apache.cassandra.schema.TableParams.Builder
-
- speculativeRetry - Variable in class org.apache.cassandra.schema.TableParams
-
- SpeculativeRetryParam - Class in org.apache.cassandra.schema
-
- SpeculativeRetryParam.Kind - Enum in org.apache.cassandra.schema
-
- SpinningDiskOptimizationStrategy - Class in org.apache.cassandra.io.util
-
- SpinningDiskOptimizationStrategy() - Constructor for class org.apache.cassandra.io.util.SpinningDiskOptimizationStrategy
-
- split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
-
- split(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the provided readers from this Transaction, and return a new Transaction to manage them
only permitted to be called if the current Transaction has never been used
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Split a composite column names into it's components.
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
Split a tuple value into its component values.
- split(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?),
where ? means that the same type of AbstractBounds is returned as the original.
- split(T) - Method in class org.apache.cassandra.dht.Bounds
-
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- split(Token, Token, double) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate a Token which take approximate 0 <= ratioToLeft <= 1 ownership of the given range.
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- split(T) - Method in class org.apache.cassandra.dht.Range
-
- split() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Splits the range containing the given token, if no tree limits would be
violated.
- split(Token) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Split the MerkleTree responsible for the given token.
- splitBlock() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- SplitController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- spliterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- splitName(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- splitOwnedRanges(int, List<Range<Token>>, 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
-
- SplittingCompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- SplittingSizeTieredCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
-
CompactionAwareWriter that splits input in differently sized sstables
Biggest sstable will be total_compaction_size / 2, second biggest total_compaction_size / 4 etc until
the result would be sub 50MB, all those are put in the same
- SplittingSizeTieredCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- SplittingSizeTieredCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
-
- spProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- SsdDiskOptimizationStrategy - Class in org.apache.cassandra.io.util
-
- SsdDiskOptimizationStrategy(double) - Constructor for class org.apache.cassandra.io.util.SsdDiskOptimizationStrategy
-
- SSL_ALGORITHM - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_CIPHER_SUITES - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_KEYSTORE - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_KEYSTORE_PW - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_PROTOCOL - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- ssl_storage_port - Variable in class org.apache.cassandra.config.Config
-
- SSL_STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_STORE_TYPE - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_TRUSTSTORE - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSL_TRUSTSTORE_PW - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSLFactory - Class in org.apache.cassandra.security
-
A Factory for providing and setting up Client and Server SSL wrapped
Socket and ServerSocket
- SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
-
- sslStoragePort - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- SSLTransportFactory - Class in org.apache.cassandra.thrift
-
- SSLTransportFactory() - Constructor for class org.apache.cassandra.thrift.SSLTransportFactory
-
- ssProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- sstable - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- sstable(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
-
- sstable - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- SSTable - Class in org.apache.cassandra.io.sstable
-
This class is built on top of the SequenceFile.
- SSTable(Descriptor, Set<Component>, CFMetaData, DiskOptimizationStrategy) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SSTABLE_ACTIVITY - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.schema.CompressionParams
-
Deprecated.
- sstable_preemptive_open_interval_in_mb - Variable in class org.apache.cassandra.config.Config
-
- SSTableAddedNotification - Class in org.apache.cassandra.notifications
-
- SSTableAddedNotification(Iterable<SSTableReader>) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
-
- sstableComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- sstableCompressionRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- sstableCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- SSTableDeletingNotification - Class in org.apache.cassandra.notifications
-
Fired right before removing an SSTable.
- SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- SSTableExpiredBlockers - Class in org.apache.cassandra.tools
-
During compaction we can drop entire sstables if they only contain expired tombstones and if it is guaranteed
to not cover anything in other sstables.
- SSTableExpiredBlockers() - Constructor for class org.apache.cassandra.tools.SSTableExpiredBlockers
-
- SSTableExport - Class in org.apache.cassandra.tools
-
Export SSTables to JSON format.
- SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
-
- SSTableFlushObserver - Interface in org.apache.cassandra.io.sstable.format
-
Observer for events in the lifecycle of writing out an sstable.
- SSTableFormat - Interface in org.apache.cassandra.io.sstable.format
-
Provides the accessors to data on disk.
- SSTableFormat.Type - Enum in org.apache.cassandra.io.sstable.format
-
- SSTableHeaderFix - Class in org.apache.cassandra.io.sstable
-
Validates and fixes type issues in the serialization-header of sstables.
- SSTableHeaderFix.Builder - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator(SSTableReader, DecoratedKey, DeletionTime, String, SSTableSimpleIterator) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- SSTableIndex - Class in org.apache.cassandra.index.sasi
-
- SSTableIndex(ColumnIndex, File, SSTableReader) - Constructor for class org.apache.cassandra.index.sasi.SSTableIndex
-
- SSTableIntervalTree - Class in org.apache.cassandra.db.lifecycle
-
- SSTableIterator - Class in org.apache.cassandra.db.columniterator
-
A Cell Iterator over SSTable
- SSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.SSTableIterator
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- sstableLevel - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sstableLevel - Variable in class org.apache.cassandra.streaming.StreamReader
-
- SSTableLevelResetter - Class in org.apache.cassandra.tools
-
Reset level to 0 on a given set of sstables
- SSTableLevelResetter() - Constructor for class org.apache.cassandra.tools.SSTableLevelResetter
-
- SSTableListChangedNotification - Class in org.apache.cassandra.notifications
-
- SSTableListChangedNotification(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- sstableLister(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) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
-
- SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
-
- sstableMap - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- sstableMetadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableMetadataViewer - Class in org.apache.cassandra.tools
-
Shows the contents of sstable metadata
- SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
-
- SSTableMultiWriter - Interface in org.apache.cassandra.io.sstable
-
- SSTableOfflineRelevel - Class in org.apache.cassandra.tools
-
Create a decent leveling for the given keyspace/column family
Approach is to sort the sstables by their last token
given an original leveling like this (note that [ ] indicates token boundaries, not sstable size on disk, all sstables are the same size)
L3 [][][][][][][][][][][]
L2 [ ][ ][ ][ ]
L1 [ ][ ]
L0 [ ]
Will look like this after being dropped to L0 and sorted by last token (and, to illustrate overlap, the overlapping ones are put on a new line):
[][][]
[ ][][][]
[ ]
[ ]
...
- SSTableOfflineRelevel() - Constructor for class org.apache.cassandra.tools.SSTableOfflineRelevel
-
- sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableReader - Class in org.apache.cassandra.io.sstable.format
-
An SSTableReader can be constructed in a number of places, but typically is either
read from disk at startup, or constructed from a flushed memtable, or after compaction
to replace some existing sstables.
- SSTableReader(Descriptor, Set<Component>, CFMetaData, long, StatsMetadata, SSTableReader.OpenReason, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableReader.Factory - Class in org.apache.cassandra.io.sstable.format
-
- SSTableReader.OpenReason - Enum in org.apache.cassandra.io.sstable.format
-
- SSTableReader.Operator - Class in org.apache.cassandra.io.sstable.format
-
TODO: Move someplace reusable
- SSTableReader.UniqueIdentifier - Class in org.apache.cassandra.io.sstable.format
-
- SSTableReadsListener - Interface in org.apache.cassandra.io.sstable.format
-
Listener for receiving notifications associated with reading SSTables.
- SSTableReadsListener.SelectionReason - Enum in org.apache.cassandra.io.sstable.format
-
The reasons for selecting an SSTable
- SSTableReadsListener.SkippingReason - Enum in org.apache.cassandra.io.sstable.format
-
The reasons for skipping an SSTable
- SSTableRepairedAtSetter - Class in org.apache.cassandra.tools
-
Set repairedAt status on a given set of sstables.
- SSTableRepairedAtSetter() - Constructor for class org.apache.cassandra.tools.SSTableRepairedAtSetter
-
- SSTableRepairStatusChanged - Class in org.apache.cassandra.notifications
-
- SSTableRepairStatusChanged(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.notifications.SSTableRepairStatusChanged
-
- SSTableReversedIterator - Class in org.apache.cassandra.db.columniterator
-
A Cell Iterator in reversed clustering order over SSTable
- SSTableReversedIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.SSTableReversedIterator
-
- SSTableRewriter - Class in org.apache.cassandra.io.sstable
-
Wraps one or more writers as output for rewriting one or more readers: every sstable_preemptive_open_interval_in_mb
we look in the summary we're collecting for the latest writer for the penultimate key that we know to have been fully
flushed to the index file, and then double check that the key is fully present in the flushed data file.
- SSTableRewriter(ILifecycleTransaction, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
Deprecated.
- SSTableRewriter(ILifecycleTransaction, long, boolean, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
Deprecated.
- SSTableRewriter(ILifecycleTransaction, long, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- sstables - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- sstables(SSTableSet, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
-
- sstables - Variable in class org.apache.cassandra.notifications.SSTableRepairStatusChanged
-
- sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
-
- SSTableSet - Enum in org.apache.cassandra.db.lifecycle
-
- SSTablesGlobalTracker - Class in org.apache.cassandra.service
-
Tracks all sstables in use on the local node.
- SSTablesGlobalTracker(SSTableFormat.Type) - Constructor for class org.apache.cassandra.service.SSTablesGlobalTracker
-
- SSTableSimpleIterator - Class in org.apache.cassandra.io.sstable
-
Utility class to handle deserializing atom from sstables.
- sstablesInBounds(PartitionPosition, PartitionPosition, SSTableIntervalTree) - Static method in class org.apache.cassandra.db.lifecycle.View
-
- sstablesInEachLevel - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
-
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Histogram of the number of sstable data files accessed per read
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Histogram of the number of sstable data files accessed per read
- SSTableSplitter - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
-
- SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
-
- sstablesRewrite(boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- sstablesTracker - Variable in class org.apache.cassandra.service.StorageService
-
- SSTableStreamingSections(Ref<SSTableReader>, List<Pair<Long, Long>>, long, long) - Constructor for class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- SSTablesVersionsInUseChangeNotification - Class in org.apache.cassandra.service
-
Notification triggered by a
SSTablesGlobalTracker
when the set of sstables versions in use on this node
changes.
- SSTableTxnWriter - Class in org.apache.cassandra.io.sstable
-
A wrapper for SSTableWriter and LifecycleTransaction to be used when
the writer is the only participant in the transaction and therefore
it can safely own the transaction.
- SSTableTxnWriter(LifecycleTransaction, SSTableMultiWriter) - Constructor for class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
- sstableVersions(Set<VersionAndType>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- sstableWindowSize - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- sstableWindowUnit - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- sstableWriter - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- SSTableWriter - Class in org.apache.cassandra.io.sstable.format
-
This is the API all table writers must implement.
- SSTableWriter(Descriptor, long, long, CFMetaData, MetadataCollector, SerializationHeader, Collection<SSTableFlushObserver>) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- SSTableWriter.Factory - Class in org.apache.cassandra.io.sstable.format
-
- SSTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
-
- Stage - Enum in org.apache.cassandra.concurrent
-
- StageManager - Class in org.apache.cassandra.concurrent
-
This class manages executor services for Messages recieved: each Message requests
running on a specific "stage" for concurrency control; hence the Map approach,
even though stages (executors) are not created dynamically.
- StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
-
- StandaloneScrubber - Class in org.apache.cassandra.tools
-
- StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
-
- StandaloneSplitter - Class in org.apache.cassandra.tools
-
- StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
-
- StandaloneSSTableUtil - Class in org.apache.cassandra.tools
-
- StandaloneSSTableUtil() - Constructor for class org.apache.cassandra.tools.StandaloneSSTableUtil
-
- StandaloneUpgrader - Class in org.apache.cassandra.tools
-
- StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
-
- StandaloneVerifier - Class in org.apache.cassandra.tools
-
- StandaloneVerifier() - Constructor for class org.apache.cassandra.tools.StandaloneVerifier
-
- Standard(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader.Standard
-
- StandardAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
-
- StandardAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
-
- StandardAnalyzer.TokenType - Enum in org.apache.cassandra.index.sasi.analyzer
-
- StandardTokenizerImpl - Class in org.apache.cassandra.index.sasi.analyzer
-
- StandardTokenizerImpl(Reader) - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerImpl
-
Creates a new scanner
- StandardTokenizerInterface - Interface in org.apache.cassandra.index.sasi.analyzer
-
Internal interface for supporting versioned grammars.
- StandardTokenizerOptions - Class in org.apache.cassandra.index.sasi.analyzer
-
Various options for controlling tokenization and enabling
or disabling features
- StandardTokenizerOptions() - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
-
- StandardTokenizerOptions.OptionsBuilder - Class in org.apache.cassandra.index.sasi.analyzer
-
- start() - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- start() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
-
- start - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- start(Object...) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
-
Sets the start for the built range using the provided values.
- start() - Method in class org.apache.cassandra.db.Slice
-
- start(int) - Method in class org.apache.cassandra.gms.Gossiper
-
- start(int, Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.Gossiper
-
Start the gossiper with the generation number, preloading the map of application states before starting
- start() - Method in interface org.apache.cassandra.index.transactions.IndexTransaction
-
- start() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- start(ListeningExecutorService) - Method in class org.apache.cassandra.repair.RepairSession
-
Start RepairJob on given ColumnFamilies.
- start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Start the server.
- start() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
-
- start() - Method in class org.apache.cassandra.service.MigrationCoordinator
-
- start() - Method in class org.apache.cassandra.service.NativeTransportService
-
Starts native transport servers.
- start() - Method in class org.apache.cassandra.streaming.StreamSession
-
- start() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- start() - Method in class org.apache.cassandra.transport.Server
-
- start() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
Start an operation against this OpOrder.
- start_native_transport - Variable in class org.apache.cassandra.config.Config
-
- start_rpc - Variable in class org.apache.cassandra.config.Config
-
- startAt(OnDiskBlock<OnDiskIndex.DataTerm>, Expression) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
-
- startAt(OnDiskBlock.SearchResult<OnDiskIndex.DataTerm>, boolean) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
-
- startBatchlogReplay() - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
- 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
-
- startGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startKey() - Method in class org.apache.cassandra.db.DataRange
-
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(ColumnDefinition) - Method in class org.apache.cassandra.db.rows.SerializationHelper
-
- startParentRepair(UUID, String, String[], RepairOption) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- startPartition(DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
-
- startPartition(DecoratedKey, long) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
-
- startRepairs(UUID, UUID, String, String[], Collection<Range<Token>>, Iterable<InetAddress>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- startRpc() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- starts() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
-
- startsAfterCurrentRow(LegacyLayout.LegacyRangeTombstone) - Method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
Whether the provided range tombstone starts strictly after the current row of the cell grouper (if no row is
currently started, this return false).
- startsWith(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.LocalSyncTask
-
Starts sending/receiving our list of differences to/from the remote endpoint: creates a callback
that will be called out of band once the streams complete.
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.RemoteSyncTask
-
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.SyncTask
-
- startThriftServer() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
-
- startTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- startup() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Performs any extra initialization required
- startup() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- StartupCheck - Interface in org.apache.cassandra.service
-
A test to determine if the system is in a valid state to start up.
- startupChecks - Variable in class org.apache.cassandra.service.CassandraDaemon
-
- StartupChecks - Class in org.apache.cassandra.service
-
Verifies that the system and environment is in a fit state to be started.
- StartupChecks() - Constructor for class org.apache.cassandra.service.StartupChecks
-
- StartupException - Exception in org.apache.cassandra.exceptions
-
An exception thrown during system startup, indicating the environment or system
is not in a valid state to startup.
- StartupException(int, String) - Constructor for exception org.apache.cassandra.exceptions.StartupException
-
- StartupException(int, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.StartupException
-
- StartupMessage - Class in org.apache.cassandra.transport.messages
-
The initial message of the protocol.
- StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
-
- startViewBuild(String, String, UUID) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- stat - Variable in class org.apache.cassandra.repair.SyncTask
-
- state(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- state - Variable in class org.apache.cassandra.index.sasi.utils.AbstractIterator
-
- State() - Constructor for class org.apache.cassandra.service.ClientWarn.State
-
- state() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
-
- state() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
-
- state() - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
-
- state() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Get the current state of the pager.
- state() - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
-
- state - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Current session state
- state(StreamSession.State) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set current state to newState
.
- state() - Method in class org.apache.cassandra.streaming.StreamSession
-
- state() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- state() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- stateFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- statement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- StatementRestrictions - Class in org.apache.cassandra.cql3.restrictions
-
The restrictions corresponding to the relations specified on the where-clause of CQL query.
- StatementRestrictions(StatementType, CFMetaData, WhereClause, VariableSpecifications, boolean, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- StatementType - Enum in org.apache.cassandra.cql3.statements
-
- states() - Method in class org.apache.cassandra.gms.EndpointState
-
- stateType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- STATIC_BUILDER - Static variable in class org.apache.cassandra.db.CBuilder
-
- STATIC_CLUSTERING - Static variable in interface org.apache.cassandra.db.Clustering
-
The special cased clustering used by all static rows.
- STATIC_MARKER - Static variable in class org.apache.cassandra.db.marshal.CompositeType
-
- STATIC_PREFIX - Static variable in class org.apache.cassandra.db.LegacyLayout
-
- staticDef(CFMetaData, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- staticDef(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- staticGrouper(CFMetaData, SerializationHelper) - Static method in class org.apache.cassandra.db.LegacyLayout.CellGrouper
-
- staticOperations() - Method in class org.apache.cassandra.cql3.Operations
-
Returns the operation on static columns.
- staticRow - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- staticRow() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- staticRow() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- staticRow() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
- staticRow - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- staticRow() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- staticRow() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
-
The static part corresponding to this partition (this can be an empty
row but cannot be null
).
- staticRow() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- staticRow - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- staticRow() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
-
- staticRow() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- staticRow() - Method in class org.apache.cassandra.db.transform.BaseRows
-
- staticRow() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- staticRow() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- statics - Variable in class org.apache.cassandra.db.PartitionColumns
-
- StaticTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
-
- StaticTokenTreeBuilder(CombinedTerm) - Constructor for class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
-
- statistics - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
-
- Statistics(RangeIterator.Builder.IteratorType) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- stats() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
-
- stats() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
-
- stats() - Method in interface org.apache.cassandra.db.partitions.Partition
-
- stats() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
- stats - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- stats() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
-
- stats() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
-
- stats() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterator
-
Return "statistics" about what is returned by this iterator.
- stats() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
-
- stats() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
-
- stats() - Method in class org.apache.cassandra.db.SerializationHeader
-
- STATS - Static variable in class org.apache.cassandra.io.sstable.Component
-
- stats() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- stats() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- stats - Variable in class org.apache.cassandra.repair.RepairResult
-
- stats() - Method in class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- 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 - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata that always stay on heap.
- StatsMetadata(EstimatedHistogram, EstimatedHistogram, IntervalSet<CommitLogPosition>, long, long, int, int, int, int, double, StreamingHistogram, int, List<ByteBuffer>, List<ByteBuffer>, boolean, long, long, long, UUID) - 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
-
- statToString(SummaryStatistics) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
-
- Status - Class in org.apache.cassandra.tools.nodetool
-
- Status() - Constructor for class org.apache.cassandra.tools.nodetool.Status
-
- status - Variable in class org.apache.cassandra.transport.Event.StatusChange
-
- STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_BOOTSTRAPPING_REPLACE - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- StatusBackup - Class in org.apache.cassandra.tools.nodetool
-
- StatusBackup() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBackup
-
- StatusBinary - Class in org.apache.cassandra.tools.nodetool
-
- StatusBinary() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBinary
-
- statusCode - Variable in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
- StatusGossip - Class in org.apache.cassandra.tools.nodetool
-
- StatusGossip() - Constructor for class org.apache.cassandra.tools.nodetool.StatusGossip
-
- StatusHandoff - Class in org.apache.cassandra.tools.nodetool
-
- StatusHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.StatusHandoff
-
- StatusLogger - Class in org.apache.cassandra.utils
-
- StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
-
- StatusThrift - Class in org.apache.cassandra.tools.nodetool
-
- StatusThrift() - Constructor for class org.apache.cassandra.tools.nodetool.StatusThrift
-
- StemmerFactory - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Returns a SnowballStemmer instance appropriate for
a given language
- StemmerFactory() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmerFactory
-
- StemmingFilters - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Filters for performing Stemming on tokens
- StemmingFilters() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmingFilters
-
- StemmingFilters.DefaultStemmingFilter - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
- stemTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
-
- step - Variable in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
-
- stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- stop - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- 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.gms.Gossiper
-
- stop() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Stop the client.
- stop() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Stop the server.
- stop() - Method in class org.apache.cassandra.service.CassandraDaemon
-
Stop the daemon, ideally in an idempotent manner.
- stop(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- stop() - Method in class org.apache.cassandra.service.NativeTransportService
-
Stops currently running native transport servers.
- stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- stop() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Stop - Class in org.apache.cassandra.tools.nodetool
-
- Stop() - Constructor for class org.apache.cassandra.tools.nodetool.Stop
-
- stop() - Method in class org.apache.cassandra.tracing.TraceState
-
- stop() - Method in class org.apache.cassandra.transport.Server
-
- 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
-
- stopGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopInPartition() - Method in class org.apache.cassandra.db.transform.StoppingTransformation
-
If invoked by a subclass, any rows/unfiltered iterator this transformation has been applied to will terminate
after any currently-processing item is returned
- stopKey() - Method in class org.apache.cassandra.db.DataRange
-
The end of the partition key range queried by this DataRange
.
- stopNativeTransport() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- stopNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- StoppingTransformation<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.transform
-
- StoppingTransformation() - Constructor for class org.apache.cassandra.db.transform.StoppingTransformation
-
- stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopSession() - Method in class org.apache.cassandra.tracing.Tracing
-
Stop the session and record its complete.
- stopSessionImpl() - Method in class org.apache.cassandra.tracing.Tracing
-
- stopShutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.gms.Gossiper
-
- stopThriftServer() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopTransports() - Method in class org.apache.cassandra.service.StorageService
-
- stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Stops CL, for testing purposes.
- stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- StopWordFactory - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Provides a list of Stop Words for a given language
- StopWordFactory() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFactory
-
- StopWordFilters - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
Filter implementations for input matching Stop Words
- StopWordFilters() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFilters
-
- StopWordFilters.DefaultStopWordFilter - Class in org.apache.cassandra.index.sasi.analyzer.filter
-
- storage_port - Variable in class org.apache.cassandra.config.Config
-
- STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- StorageHook - Interface in org.apache.cassandra.db
-
- StorageMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Storage.
- StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
-
- storagePort - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- StorageProxy - Class in org.apache.cassandra.service
-
- StorageProxy.RangeCommandIterator - Class in org.apache.cassandra.service
-
- StorageProxy.RangeForQuery - Class in org.apache.cassandra.service
-
- StorageProxy.RangeIterator - Class in org.apache.cassandra.service
-
- StorageProxy.RangeMerger - Class in org.apache.cassandra.service
-
- StorageProxy.WritePerformer - Interface in org.apache.cassandra.service
-
- StorageProxyMBean - Interface in org.apache.cassandra.service
-
- StorageService - Class in org.apache.cassandra.service
-
This abstraction contains the token/identifier of this node
on the identifier space.
- StorageService() - Constructor for class org.apache.cassandra.service.StorageService
-
- StorageServiceMBean - Interface in org.apache.cassandra.service
-
- store(Batch) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
-
- store(Batch, boolean) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
-
- store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- storeKeyspaceInstance(Keyspace) - Method in class org.apache.cassandra.config.Schema
-
Store given Keyspace instance to the schema
- storePreparedStatement(String, String, ParsedStatement.Prepared, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- storeRows() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- strategyLogger() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- strategyLogger() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- strategyLogger() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- stream() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream(Set<InetAddress>, StreamEventHandler...) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream() - Method in class org.apache.cassandra.schema.Functions
-
- stream() - Method in class org.apache.cassandra.schema.Keyspaces
-
- STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- StreamConnectionFactory - Interface in org.apache.cassandra.streaming
-
Interface that creates connection used by streaming.
- StreamCoordinator - Class in org.apache.cassandra.streaming
-
StreamCoordinator
is a helper class that abstracts away maintaining multiple
StreamSession and ProgressInfo instances per peer.
- StreamCoordinator(int, boolean, boolean, StreamConnectionFactory, boolean) - Constructor for class org.apache.cassandra.streaming.StreamCoordinator
-
- StreamDeserializer(CFMetaData, InputStream, Version, SerializationHeader, long, UUID) - Constructor for class org.apache.cassandra.streaming.StreamReader.StreamDeserializer
-
- StreamEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent(StreamEvent.Type, UUID) - Constructor for class org.apache.cassandra.streaming.StreamEvent
-
- StreamEvent.ProgressEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionCompleteEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionPreparedEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.Type - Enum in org.apache.cassandra.streaming
-
- StreamEventHandler - Interface in org.apache.cassandra.streaming
-
- StreamEventJMXNotifier - Class in org.apache.cassandra.streaming.management
-
- StreamEventJMXNotifier() - Constructor for class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
-
- StreamException - Exception in org.apache.cassandra.streaming
-
- StreamException(StreamState, String) - Constructor for exception org.apache.cassandra.streaming.StreamException
-
- StreamException(StreamState, String, Throwable) - Constructor for exception org.apache.cassandra.streaming.StreamException
-
- StreamHook - Interface in org.apache.cassandra.streaming
-
- streamId - Variable in class org.apache.cassandra.transport.Frame.Header
-
- streaming_keep_alive_period_in_secs - Variable in class org.apache.cassandra.config.Config
-
- streaming_socket_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- StreamingHistogram - Class in org.apache.cassandra.utils
-
Histogram that can be constructed from streaming of data.
- StreamingHistogram.StreamingHistogramBuilder - Class in org.apache.cassandra.utils
-
- StreamingHistogram.StreamingHistogramSerializer - Class in org.apache.cassandra.utils
-
- StreamingHistogramBuilder(int, int, int) - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramBuilder
-
Creates a new histogram with max bin size of maxBinSize
- StreamingHistogramSerializer() - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- StreamingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for streaming.
- StreamingMetrics(InetAddress) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
-
- StreamingRepairTask - Class in org.apache.cassandra.repair
-
StreamingRepairTask performs data streaming between two remote replica which neither is not repair coordinator.
- StreamingRepairTask(RepairJobDesc, SyncRequest, long) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
-
- StreamInitMessage - Class in org.apache.cassandra.streaming.messages
-
StreamInitMessage is first sent from the node where
StreamSession
is started,
to initiate corresponding
StreamSession
on the other side.
- StreamInitMessage(InetAddress, int, UUID, String, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- StreamManager - Class in org.apache.cassandra.streaming
-
StreamManager manages currently running
StreamResultFuture
s and provides status of all operation invoked.
- StreamManager() - Constructor for class org.apache.cassandra.streaming.StreamManager
-
- StreamManager.StreamRateLimiter - Class in org.apache.cassandra.streaming
-
- StreamManagerMBean - Interface in org.apache.cassandra.streaming
-
- StreamMessage - Class in org.apache.cassandra.streaming.messages
-
StreamMessage is an abstract base class that every messages in streaming protocol inherit.
- StreamMessage(StreamMessage.Type) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessage
-
- StreamMessage.Serializer<V extends StreamMessage> - Interface in org.apache.cassandra.streaming.messages
-
StreamMessage serializer
- StreamMessage.Type - Enum in org.apache.cassandra.streaming.messages
-
StreamMessage types
- StreamPlan - Class in org.apache.cassandra.streaming
-
StreamPlan
is a helper class that builds StreamOperation of given configuration.
- StreamPlan(String) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
Start building stream plan.
- StreamPlan(String, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
- StreamPlan(String, long, int, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
- streamProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- StreamRateLimiter(InetAddress) - Constructor for class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
-
- StreamReader - Class in org.apache.cassandra.streaming
-
StreamReader reads from stream and writes to SSTable.
- StreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamReader
-
- StreamReader.StreamDeserializer - Class in org.apache.cassandra.streaming
-
- StreamReceiveTask - Class in org.apache.cassandra.streaming
-
Task that manages receiving files for the session for certain ColumnFamily.
- StreamReceiveTask(StreamSession, UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
-
- StreamRequest - Class in org.apache.cassandra.streaming
-
- StreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Constructor for class org.apache.cassandra.streaming.StreamRequest
-
- StreamRequest.StreamRequestSerializer - Class in org.apache.cassandra.streaming
-
- StreamRequestSerializer() - Constructor for class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- StreamResultFuture - Class in org.apache.cassandra.streaming
-
A future on the result (
StreamState
) of a streaming plan.
- StreamSession - Class in org.apache.cassandra.streaming
-
Handles the streaming a one or more section of one of more sstables to and from a specific
remote node.
- StreamSession(InetAddress, InetAddress, StreamConnectionFactory, int, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamSession
-
Create new streaming session with the peer.
- StreamSession.SSTableStreamingSections - Class in org.apache.cassandra.streaming
-
- StreamSession.State - Enum in org.apache.cassandra.streaming
-
- StreamState - Class in org.apache.cassandra.streaming
-
Current snapshot of streaming progress.
- StreamState(UUID, String, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
-
- StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- StreamStateStore - Class in org.apache.cassandra.dht
-
Store and update available ranges (data already received) to system keyspace.
- StreamStateStore() - Constructor for class org.apache.cassandra.dht.StreamStateStore
-
- StreamSummary - Class in org.apache.cassandra.streaming
-
Summary of streaming.
- StreamSummary(UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamSummary
-
- StreamSummary.StreamSummarySerializer - Class in org.apache.cassandra.streaming
-
- StreamSummaryCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamSummaryCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- StreamSummarySerializer() - Constructor for class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- StreamTask - Class in org.apache.cassandra.streaming
-
StreamTask is an abstraction of the streaming task performed over specific ColumnFamily.
- StreamTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTask
-
- StreamTransferTask - Class in org.apache.cassandra.streaming
-
StreamTransferTask sends sections of SSTable files in certain ColumnFamily.
- StreamTransferTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
-
- StreamWriter - Class in org.apache.cassandra.streaming
-
StreamWriter writes given section of the SSTable to given channel.
- StreamWriter(SSTableReader, Collection<Pair<Long, Long>>, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamWriter
-
- strictFlushing - Variable in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- strictlyWrapsAround(T, T) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
Whether left
and right
forms a wrapping interval, that is if unwrapping wouldn't be a no-op.
- strictRuntimeChecks() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyCollectionsParameters(Map<ByteBuffer, ? extends CollectionType>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- stringifyTypeParameters(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyTypeParameters(List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyUserTypeParameters(String, ByteBuffer, List<FieldIdentifier>, List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- StringSerializer() - Constructor for class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- StringToken(String) - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
-
- 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.utils.btree.BTreeSet.BTreeDescRange
-
- subList(int, int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- subList(int, int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- subMap(K, K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
-
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
Task Submission / Creation / Objects
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- submitAntiCompaction(ColumnFamilyStore, Collection<Range<Token>>, Refs<SSTableReader>, long, UUID) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Submit anti-compactions for a collection of SSTables over a set of repaired ranges and marks corresponding SSTables
as repaired.
- submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Call this whenever a compaction might be needed on the given columnfamily.
- submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitHint(Mutation, InetAddress, AbstractWriteResponseHandler<IMutation>) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitHint(Mutation, Collection<InetAddress>, AbstractWriteResponseHandler<IMutation>) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Is not scheduled, because it is performing disjoint work from sstable compaction.
- submitMaximal(ColumnFamilyStore, int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitRepairSession(UUID, Collection<Range<Token>>, String, RepairParallelism, Set<InetAddress>, long, boolean, ListeningExecutorService, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Requests repairs for the given keyspace and column families.
- submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitValidation(ColumnFamilyStore, Validator) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Does not mutate data, so is not scheduled.
- submitViewBuilder(ViewBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- SubPool(long, float) - Constructor for class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- subSet(V, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- Substracter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
-
- Substraction(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Substraction
-
- subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- subtract(InputPosition) - Method in interface org.apache.cassandra.hints.InputPosition
-
- subtractAll(Collection<Range<T>>) - Method in class org.apache.cassandra.dht.Range
-
- SubtracterByKey(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SubtracterByKey
-
- subtype(int) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Returns the type of the ith clustering column of the table.
- subtypes() - Method in class org.apache.cassandra.db.ClusteringComparator
-
The "subtypes" of this clustering comparator, that is the types of the clustering
columns for the table this is a comparator of.
- success - Variable in class org.apache.cassandra.db.TruncateResponse
-
- success - Variable in class org.apache.cassandra.metrics.AuthMetrics
-
Number and rate of successful logins
- success - Variable in class org.apache.cassandra.repair.messages.SyncComplete
-
true if sync success, false otherwise
- success() - Method in class org.apache.cassandra.repair.messages.ValidationComplete
-
- success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- successfulParentRepair(UUID, Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- successfulRanges - Variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
-
Successfully repaired ranges.
- successfulRepairJob(UUID, String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- successfulViewBuild(String, String, UUID) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- sufficientForStartupSafetyCheck(Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
- SuffixSA - Class in org.apache.cassandra.index.sasi.sa
-
- SuffixSA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.SuffixSA
-
- sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
-
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.streaming.messages.PrepareMessage
-
Summaries of streaming out
- SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
-
- summaryCount - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- SUPER_BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
- SUPER_COLUMN_MAP_COLUMN - Static variable in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
- SUPER_COLUMN_MAP_COLUMN_STR - Static variable in class org.apache.cassandra.cql3.SuperColumnCompatibility
-
- superBlockCnt - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
-
- superBlocksOffset - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
-
- SuperColumnCompatibility - Class in org.apache.cassandra.cql3
-
Class incapsulating the helper logic to handle SELECT / UPDATE / INSERT special-cases related
to SuperColumn tables in applicable scenarios.
- SuperColumnCompatibility() - Constructor for class org.apache.cassandra.cql3.SuperColumnCompatibility
-
- SuperColumnCompatibility.SuperColumnRestrictions - Class in org.apache.cassandra.cql3
-
Restrictions are the trickiest part of the SuperColumn integration.
- superColumnCountingLimits(int, int) - Static method in class org.apache.cassandra.db.filter.DataLimits
-
- superColumnKeyColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- SuperColumnKeyEQRestriction(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyEQRestriction
-
- SuperColumnKeyINRestriction(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestriction
-
- SuperColumnKeyINRestrictionWithMarkers(ColumnDefinition, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestrictionWithMarkers
-
- SuperColumnKeyINRestrictionWithValues(ColumnDefinition, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeyINRestrictionWithValues
-
- SuperColumnKeySliceRestriction(ColumnDefinition, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnKeySliceRestriction
-
- SuperColumnMultiEQRestriction(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiEQRestriction
-
- SuperColumnMultiSliceRestriction(ColumnDefinition, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiSliceRestriction
-
- superColumnName() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- SuperColumnRestrictions(Iterator<SingleRestriction>) - Constructor for class org.apache.cassandra.cql3.SuperColumnCompatibility.SuperColumnRestrictions
-
- superColumnSubName() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- superColumnValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- supersedes(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- supersedes(LivenessInfo) - Method in class org.apache.cassandra.db.LivenessInfo
-
Whether this liveness information supersedes another one (that is
whether is has a greater timestamp than the other or not).
- supersedes(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- supersedes(Row.Deletion) - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- SUPPORTED - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
-
All supported versions, published as an enumset
- SupportedMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
-
- supportedOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- supportedOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Set of options supported by CREATE ROLE and ALTER ROLE queries.
- supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- supportedVersions() - Static method in enum org.apache.cassandra.transport.ProtocolVersion
-
- supportExitOnOutOfMemory(String) - Static method in class org.apache.cassandra.utils.JavaUtils
-
Checks if the specified JRE support ExitOnOutOfMemory and CrashOnOutOfMemory.
- supports(Operator) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- supports(Expression.Op) - Method in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- supports(Expression.Op) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
-
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supports(BufferType) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
Checks if the given buffer would be supported by the compressor.
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- SUPPORTS_GLOBAL_PREPARE_FLAG_VERSION - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- supportsBackPressure() - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- supportsBackPressure() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- 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(ColumnDefinition, 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(ColumnDefinition, Operator) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- supportsExpression(ColumnDefinition, Operator) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- supportsFreezing() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- supportsOperator(ColumnDefinition, 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(ColumnDefinition, Operator) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
-
- supportsOperator(ColumnDefinition, Operator) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
-
- supportsReplicaFilteringProtection(RowFilter) - Method in interface org.apache.cassandra.index.Index
-
Tells whether this index supports replica fitering protection or not.
- supportsReplicaFilteringProtection(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- supportsThresholdParams(Class<? extends AbstractCompactionStrategy>) - Static method in class org.apache.cassandra.schema.CompactionParams
-
- switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Implementations of this method should finish the current sstable writer and start writing to this directory.
- switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
-
- switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
-
- switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
-
- switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- switchMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- switchMemtable(boolean, Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
Switch the current memtable.
- switchMemtable() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- switchMemtable(Memtable) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
- switchMemtableIfCurrent(Memtable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Switches the memtable iff the live memtable is the one provided
- switchWriter(SSTableWriter) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- sync(boolean) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Requests commit log files sync themselves, if needed.
- sync(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Forces a disk flush on the commit log files that need it.
- sync() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Synchronize file contents with disk.
- SYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer.ThriftServerType
-
- sync(FileDescriptor) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- sync(RandomAccessFile) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- sync(FileOutputStream) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- syncBlocking() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
Request sync and wait until the current state is synced.
- syncComplete - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- SyncComplete - Class in org.apache.cassandra.repair.messages
-
- SyncComplete(RepairJobDesc, NodePair, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- SyncComplete(RepairJobDesc, InetAddress, InetAddress, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- syncComplete(boolean) - Method in class org.apache.cassandra.repair.RemoteSyncTask
-
- syncComplete(RepairJobDesc, NodePair, boolean) - Method in class org.apache.cassandra.repair.RepairSession
-
Notify this session that sync completed/failed with given NodePair
.
- syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- SyncRequest - Class in org.apache.cassandra.repair.messages
-
Body part of SYNC_REQUEST repair message.
- SyncRequest(RepairJobDesc, InetAddress, InetAddress, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
-
- SyncRequest.SyncRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- SyncRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- 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(NodePair, long) - Constructor for class org.apache.cassandra.repair.SyncStat
-
- SyncTask - Class in org.apache.cassandra.repair
-
SyncTask takes the difference of MerkleTrees between two nodes
and perform necessary operation to repair replica.
- SyncTask(RepairJobDesc, InetAddress, InetAddress, List<Range<Token>>) - Constructor for class org.apache.cassandra.repair.SyncTask
-
- SyncUtil - Class in org.apache.cassandra.utils
-
- SyncUtil() - Constructor for class org.apache.cassandra.utils.SyncUtil
-
- syncWriteToBatchlog(WriteResponseHandler<?>, Batch, Collection<InetAddress>) - Static method in class org.apache.cassandra.batchlog.LegacyBatchlogMigrator
-
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error occurs.
- syntaxError(BaseRecognizer, String) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error with a specified message occurs.
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error occurs.
- syntaxError(BaseRecognizer, String) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error with a specified message occurs.
- SyntaxException - Exception in org.apache.cassandra.exceptions
-
- SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
-
- system() - Static method in class org.apache.cassandra.db.Keyspace
-
- system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- SYSTEM_KEYSPACE_NAME - Static variable in class org.apache.cassandra.config.SchemaConstants
-
- system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
update an existing keyspace, but do not allow column family modifications.
- SYSTEM_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- SYSTEM_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- SystemDistributedKeyspace - Class in org.apache.cassandra.repair
-
- SystemKeyspace - 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
-
- SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- SystemTimeSource - Class in org.apache.cassandra.utils
-
Time source backed by JVM clock.
- SystemTimeSource() - Constructor for class org.apache.cassandra.utils.SystemTimeSource
-
- T - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- t - Variable in class org.apache.cassandra.cql3.Operation
-
- T__186 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__186 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__186 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__186 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__187 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__187 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__187 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__187 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__188 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__188 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__188 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__188 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__189 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__189 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__189 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__189 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__190 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__190 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__190 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__190 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__191 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__191 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__191 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__191 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__192 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__192 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__192 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__192 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__193 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__193 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__193 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__193 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__194 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__194 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__194 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__194 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__195 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__195 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__195 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__195 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__196 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__196 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__196 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__196 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__197 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__197 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__197 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__197 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__198 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__198 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__198 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__198 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__199 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__199 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__199 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__199 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__200 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__200 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__200 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__200 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__201 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__201 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__201 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__201 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__202 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__202 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__202 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__202 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__203 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__203 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__203 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__203 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__204 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__204 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__204 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__204 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__205 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__205 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__205 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__205 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__206 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__206 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__206 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__206 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__207 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- T__207 - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- T__207 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__207 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- table(String, String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource instance representing a table.
- TableAttributes - Class in org.apache.cassandra.cql3.statements
-
- TableAttributes() - Constructor for class org.apache.cassandra.cql3.statements.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
-
- TableHistograms - Class in org.apache.cassandra.tools.nodetool
-
- TableHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.TableHistograms
-
- TableMetrics - Class in org.apache.cassandra.metrics
-
- TableMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.TableMetrics
-
- TableMetrics.Sampler - Enum in org.apache.cassandra.metrics
-
- TableMetrics.TableHistogram - Class in org.apache.cassandra.metrics
-
- TableMetrics.TableTimer - Class in org.apache.cassandra.metrics
-
- TableParams - Class in org.apache.cassandra.schema
-
- TableParams.Builder - Class in org.apache.cassandra.schema
-
- TableParams.Option - Enum in org.apache.cassandra.schema
-
- tables - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
-
- TABLES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Tables - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's Tables.
- tables - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
-
- tables - Variable in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- Tables.Builder - Class in org.apache.cassandra.schema
-
- tablesAndViews() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- TableStats - Class in org.apache.cassandra.tools.nodetool
-
- TableStats() - Constructor for class org.apache.cassandra.tools.nodetool.TableStats
-
- TableStatsHolder - Class in org.apache.cassandra.tools.nodetool.stats
-
- TableStatsHolder(NodeProbe, boolean, boolean, List<String>) - Constructor for class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
-
- TableStatsPrinter - Class in org.apache.cassandra.tools.nodetool.stats
-
- TableStatsPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TableStatsPrinter
-
- TableViews - Class in org.apache.cassandra.db.view
-
Groups all the views for a given table.
- TableViews(CFMetaData) - Constructor for class org.apache.cassandra.db.view.TableViews
-
- TABULAR_TYPE - Static variable in class org.apache.cassandra.db.SnapshotDetailsTabularData
-
- tailMap(K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
-
- tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- tailSet(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- takeMultipleTableSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot of a multiple column family from different keyspaces.
- takeMultipleTableSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- takeMultipleTableSnapshot(String, Map<String, String>, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Take a snapshot of all column family from different keyspaces.
- takeSnapshot(String, Map<String, String>, String...) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot of a multiple column family from different keyspaces.
- takeSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot for the given keyspaces.
- takeSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- takeSnapshot(String, Map<String, String>, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Takes the snapshot of a multiple column family from different keyspaces.
- takeSnapshot(String, String, Map<String, String>, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Take a snapshot of all the keyspaces, optionally specifying only a specific column family.
- takeTableSnapshot(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot of a specific table.
- takeTableSnapshot(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- target - Variable in class org.apache.cassandra.net.CallbackInfo
-
- target - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- TARGET_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- targetIndex - Variable in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
-
- TargetParser - Class in org.apache.cassandra.index
-
- TargetParser() - Constructor for class org.apache.cassandra.index.TargetParser
-
- targetReplicas - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- targets - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- taskCompleted(StreamReceiveTask) - Method in class org.apache.cassandra.streaming.StreamSession
-
- taskCompleted(StreamTransferTask) - Method in class org.apache.cassandra.streaming.StreamSession
-
- taskExecutor - Variable in class org.apache.cassandra.repair.RepairSession
-
- tasks - Variable in class org.apache.cassandra.concurrent.SEPExecutor
-
- TCustomNonblockingServerSocket - Class in org.apache.cassandra.thrift
-
- TCustomNonblockingServerSocket(InetSocketAddress, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
-
- TCustomServerSocket - Class in org.apache.cassandra.thrift
-
Extends Thrift's TServerSocket to allow customization of various desirable TCP properties.
- TCustomServerSocket(InetSocketAddress, boolean, Integer, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomServerSocket
-
Allows fine-tuning of the server socket including keep-alive, reuse of addresses, send and receive buffer sizes.
- TCustomServerSocket(ServerSocket, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomServerSocket
-
- TCustomSocket - Class in org.apache.cassandra.thrift
-
Socket implementation of the TTransport interface.
- TCustomSocket(Socket) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
-
Constructor that takes an already created socket.
- TCustomSocket(String, int) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
-
Creates a new unconnected socket that will connect to the given host
on the given port.
- TCustomSocket(String, int, int) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
-
Creates a new unconnected socket that will connect to the given host
on the given port.
- term() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- term() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Term - Interface in org.apache.cassandra.cql3
-
A CQL3 term, i.e.
- Term(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.RangeTermTree.Term
-
- Term<T extends java.nio.Buffer> - Class in org.apache.cassandra.index.sasi.sa
-
- Term(int, T, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.Term
-
- Term - Class in org.apache.cassandra.index.sasi
-
- Term(MappedBuffer, OnDiskIndexBuilder.TermSize, boolean) - Constructor for class org.apache.cassandra.index.sasi.Term
-
- Term.MultiColumnRaw - Class in org.apache.cassandra.cql3
-
- Term.MultiItemTerminal - Class in org.apache.cassandra.cql3
-
- Term.NonTerminal - Class in org.apache.cassandra.cql3
-
A non terminal term, i.e.
- Term.Raw - Class in org.apache.cassandra.cql3
-
A parsed, non prepared (thus untyped) term.
- Term.Terminal - Class in org.apache.cassandra.cql3
-
A terminal term, one that can be reduced to a byte buffer directly.
- termCount() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
-
- Terminal() - Constructor for class org.apache.cassandra.cql3.Term.Terminal
-
- terminate() - Method in class org.apache.cassandra.repair.RepairSession
-
- terminateSessions() - Method in class org.apache.cassandra.service.ActiveRepairService
-
- TermIterator - Class in org.apache.cassandra.index.sasi.sa
-
- TermIterator() - Constructor for class org.apache.cassandra.index.sasi.sa.TermIterator
-
- TermIterator - Class in org.apache.cassandra.index.sasi
-
- Terms - Class in org.apache.cassandra.cql3
-
- Terms() - Constructor for class org.apache.cassandra.cql3.Terms
-
- terms - Variable in class org.apache.cassandra.index.sasi.sa.SA
-
- TermSelector - Class in org.apache.cassandra.cql3.selection
-
Selector representing a simple term (literals or bound variables).
- termSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
-
- termSize - Variable in class org.apache.cassandra.index.sasi.Term
-
- TermSlice - Class in org.apache.cassandra.cql3.restrictions
-
- TermTree - Interface in org.apache.cassandra.index.sasi.conf.view
-
- TermTree.Builder - Class in org.apache.cassandra.index.sasi.conf.view
-
- testAll(String, ColumnSpecification, Collection<? extends AssignmentTestable>) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- testAssignment(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignmentTestable
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- testAssignment(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.selection.Selectable
-
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
-
- 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.db.marshal.AbstractType
-
- TestRateLimiter - Class in org.apache.cassandra.utils
-
Helper class to apply rate limiting during fault injection testing;
for an example script, see test/resources/byteman/mutation_limiter.btm.
- TestRateLimiter(Rule) - Constructor for class org.apache.cassandra.utils.TestRateLimiter
-
- TFramedTransportFactory - Class in org.apache.cassandra.thrift
-
- TFramedTransportFactory() - Constructor for class org.apache.cassandra.thrift.TFramedTransportFactory
-
- ThreadAwareSecurityManager - Class in org.apache.cassandra.security
-
Custom SecurityManager
and Policy
implementation that only performs access checks
if explicitly enabled.
- ThreadLocalByteBufferHolder - Class in org.apache.cassandra.io.util
-
Utility class that allow buffers to be reused by storing them in a thread local instance.
- ThreadLocalByteBufferHolder(BufferType) - Constructor for class org.apache.cassandra.io.util.ThreadLocalByteBufferHolder
-
- threadLocalDeallocator(Runnable) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
-
Ensures that FastThreadLocal.remove()
is called when the Runnable.run()
method of the given Runnable
instance completes to ensure cleanup of FastThreadLocal
instances.
- threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ThreadPoolMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ThreadPoolExecutor
.
- ThreadPoolMetrics(ThreadPoolExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Create metrics for given ThreadPoolExecutor.
- threshold() - Method in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- thrift_framed_transport_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- thrift_max_message_length_in_mb - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- thrift_prepared_statements_cache_size_mb - Variable in class org.apache.cassandra.config.Config
-
Size of the Thrift prepared statements cache in MB.
- ThriftClientState - Class in org.apache.cassandra.thrift
-
ClientState used by thrift that also provide a QueryState.
- ThriftClientState(InetSocketAddress) - Constructor for class org.apache.cassandra.thrift.ThriftClientState
-
- thriftColumnNameType() - Method in class org.apache.cassandra.config.CFMetaData
-
- ThriftConversion - Class in org.apache.cassandra.thrift
-
Static utility methods to convert internal structure to and from thrift ones.
- ThriftConversion() - Constructor for class org.apache.cassandra.thrift.ThriftConversion
-
- thriftifyColumns(CFMetaData, Iterator<LegacyLayout.LegacyCell>) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- thriftLimits(int, int) - Static method in class org.apache.cassandra.db.filter.DataLimits
-
- ThriftResultsMerger - Class in org.apache.cassandra.thrift
-
Given an iterator on a partition of a compact table, this return an iterator that merges the
static row columns with the other results.
- ThriftServer - Class in org.apache.cassandra.thrift
-
- ThriftServer(InetAddress, int, int) - Constructor for class org.apache.cassandra.thrift.ThriftServer
-
- ThriftServer.ThriftServerType - Class in org.apache.cassandra.thrift
-
- ThriftServerType() - Constructor for class org.apache.cassandra.thrift.ThriftServer.ThriftServerType
-
- ThriftSessionManager - Class in org.apache.cassandra.thrift
-
Encapsulates the current client state (session).
- ThriftSessionManager() - Constructor for class org.apache.cassandra.thrift.ThriftSessionManager
-
- ThriftValidation - Class in org.apache.cassandra.thrift
-
This has a lot of building blocks for CassandraServer to call to make sure it has valid input
-- ensuring column names conform to the declared comparator, for instance.
- ThriftValidation() - Constructor for class org.apache.cassandra.thrift.ThriftValidation
-
- throttle - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- throttle_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- THROTTLE_MBITS - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- 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
-
- throwDuringPrepare(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- throwFirstSyntaxError() - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Throws the first syntax error found by the lexer or the parser if it exists.
- THsHaDisruptorServer - Class in org.apache.cassandra.thrift
-
- THsHaDisruptorServer(TDisruptorServer.Args) - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer
-
All the arguments to Non Blocking Server will apply here.
- THsHaDisruptorServer.Factory - Class in org.apache.cassandra.thrift
-
- tidy() - Method in class org.apache.cassandra.io.util.MmappedRegions.Tidier
-
- tidy() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
-
- time() - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
The time of the row deletion.
- TimeFcts - Class in org.apache.cassandra.cql3.functions
-
- TimeFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeFcts
-
- timeInMillisToDay(long) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- timeout() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
-
- timeout() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
-
- timeout - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- TIMEOUT_TYPES - Static variable in class org.apache.cassandra.tools.nodetool.GetTimeout
-
- timeouts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- timeouts - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Number of timeouts for specific IP
- timePattern - Static variable in class org.apache.cassandra.serializers.TimeSerializer
-
- TimeQuotaExceededException - Exception in org.apache.cassandra.index.sasi.exceptions
-
- TimeQuotaExceededException() - Constructor for exception org.apache.cassandra.index.sasi.exceptions.TimeQuotaExceededException
-
- timer(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- timer(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- TimeSerializer - Class in org.apache.cassandra.serializers
-
- TimeSerializer() - Constructor for class org.apache.cassandra.serializers.TimeSerializer
-
- timeSource - Variable in class org.apache.cassandra.net.RateBasedBackPressure
-
- TimeSource - Interface in org.apache.cassandra.utils
-
- timestamp - Variable in class org.apache.cassandra.cql3.Attributes.Raw
-
- timestamp - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- timestamp - Variable in class org.apache.cassandra.db.LivenessInfo
-
- timestamp() - Method in class org.apache.cassandra.db.LivenessInfo
-
The timestamp for this liveness info.
- timestamp(long) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
-
Sets the timestamp to use for the following additions to this builder or any derived (update or row) builder.
- timestamp(long) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
-
Sets the timestamp to use for the following additions to this builder or any derived (row) builder.
- timestamp() - Method in class org.apache.cassandra.db.rows.BufferCell
-
- timestamp() - Method in class org.apache.cassandra.db.rows.Cell
-
The cell timestamp.
- timestamp() - Method in class org.apache.cassandra.db.rows.NativeCell
-
- timestamp(long) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Sets the timestamp to use for the following additions.
- timestamp - Variable in class org.apache.cassandra.index.internal.IndexEntry
-
- timestamp - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- timestampNanos() - Method in interface org.apache.cassandra.utils.CoalescingStrategies.Coalescable
-
- timestampResolution - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- timestampResolution - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- timestampSerializedSize(long) - Method in class org.apache.cassandra.db.SerializationHeader
-
- TimestampSerializer - Class in org.apache.cassandra.serializers
-
- TimestampSerializer() - Constructor for class org.apache.cassandra.serializers.TimestampSerializer
-
- timestampToDate - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type TIMESTAMP
into a DATE
.
- timestampToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type TIMESTAMP
into an UNIX timestamp.
- 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
- TimeUUIDSerializer - Class in org.apache.cassandra.serializers
-
- TimeUUIDSerializer() - Constructor for class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- timeUuidtoDate - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of TIMEUUID
into a value of type DATE
.
- timeUuidToTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type TIMEUUID
into a value of type TIMESTAMP
.
- timeUuidToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that convert a value of type TIMEUUID
into an UNIX timestamp.
- TimeUUIDType - Class in org.apache.cassandra.db.marshal
-
- TimeWindowCompactionController - Class in org.apache.cassandra.db.compaction
-
- TimeWindowCompactionController(ColumnFamilyStore, Set<SSTableReader>, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionController
-
- TimeWindowCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- TimeWindowCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- TimeWindowCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- TimeWindowCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- TimeWindowCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- TimeWindowCompactionTask - Class in org.apache.cassandra.db.compaction
-
- TimeWindowCompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionTask
-
- TMP_EXT - Static variable in class org.apache.cassandra.io.sstable.Descriptor
-
- TMP_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
-
- tmpFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- toArray(Object[], Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Fill the target array with the contents of the provided subtree, in ascending order, starting at targetOffset
- toArray(Object[], int, int, Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- toArray() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- toByteArray(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- toByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- toByteBuffer(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- toBytes(PartitionUpdate, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Serialize a partition update as a byte buffer.
- toBytes() - Method in class org.apache.cassandra.gms.VersionedValue
-
- TOC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- toComponent() - Method in class org.apache.cassandra.db.SerializationHeader
-
- toCompositeData(UUID, ProgressInfo) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- toCompositeData(StreamEvent.SessionCompleteEvent) - Static method in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- toCompositeData(UUID, SessionInfo) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- toCompositeData(StreamState) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- toCompositeData(StreamSummary) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in interface org.apache.cassandra.cql3.CQL3Type
-
Generates CQL literal from a binary value of this type.
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
Generates CQL literal for TEXT/VARCHAR/ASCII types.
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
Builds CQL literal for a timestamp using time zone UTC and fixed date format.
- toCQLLiteral(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- toCQLString(Iterable<ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- toCQLString(Iterator<ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- 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.functions.FunctionName
-
Returns a string representation of the function name that is safe to use directly in CQL queries.
- toCQLString(CFMetaData) - Method in interface org.apache.cassandra.db.Clustering
-
- toCQLString(CFMetaData) - Method in class org.apache.cassandra.db.DataRange
-
- toCQLString(CFMetaData) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
- toCQLString(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- toCQLString(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- toCQLString() - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
- toCQLString() - Method in class org.apache.cassandra.db.ReadCommand
-
Recreate the CQL string corresponding to this query.
- toCQLString(CFMetaData) - Method in class org.apache.cassandra.db.Slices
-
- 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.
- TODELETEFILE - Static variable in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
-
- toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- toExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- toHeader(CFMetaData) - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- toHeaderParameters() - Method in class org.apache.cassandra.security.EncryptionContext
-
- toIdentifiers(Collection<ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
Converts the specified column definitions into column identifiers.
- toIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
-
- toInt(String, String, Integer) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to an integer.
- toJson(ISSTableScanner, Stream<UnfilteredRowIterator>, boolean, CFMetaData, OutputStream) - Static method in class org.apache.cassandra.tools.JsonTransformer
-
- ToJsonFct - Class in org.apache.cassandra.cql3.functions
-
- 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.ColumnToCollectionType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ListType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.LongType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.MapType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.SetType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UserType
-
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- Token - Class in org.apache.cassandra.dht
-
- Token() - Constructor for class org.apache.cassandra.dht.Token
-
- token - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
-
- Token - Class in org.apache.cassandra.index.sasi.disk
-
- Token(long) - Constructor for class org.apache.cassandra.index.sasi.disk.Token
-
- token - Variable in class org.apache.cassandra.index.sasi.disk.Token
-
- token - Variable in class org.apache.cassandra.tools.nodetool.HostStat
-
- token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- Token.KeyBound - Class in org.apache.cassandra.dht
-
- Token.TokenFactory - Class in org.apache.cassandra.dht
-
- Token.TokenSerializer - Class in org.apache.cassandra.dht
-
- TokenAllocation - Class in org.apache.cassandra.dht.tokenallocator
-
- TokenAllocation() - Constructor for class org.apache.cassandra.dht.tokenallocator.TokenAllocation
-
- TokenAllocator<Unit> - Interface in org.apache.cassandra.dht.tokenallocator
-
- TokenAllocatorBase<Unit> - Class in org.apache.cassandra.dht.tokenallocator
-
- TokenAllocatorBase(NavigableMap<Token, Unit>, ReplicationStrategy<Unit>, IPartitioner) - Constructor for class org.apache.cassandra.dht.tokenallocator.TokenAllocatorBase
-
- TokenAllocatorFactory - Class in org.apache.cassandra.dht.tokenallocator
-
- TokenAllocatorFactory() - Constructor for class org.apache.cassandra.dht.tokenallocator.TokenAllocatorFactory
-
- tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
-
- tokenCount - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- tokenCount - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
- TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
-
- TokenFct - Class in org.apache.cassandra.cql3.functions
-
- TokenFct(CFMetaData) - 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
-
- tokenMetadata - Variable in class org.apache.cassandra.dht.BootStrapper
-
- TokenMetadata - Class in org.apache.cassandra.locator
-
- TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
-
- TokenMetadata.Topology - Class in org.apache.cassandra.locator
-
Tracks the assignment of racks and endpoints in each datacenter for all the "normal" endpoints
in this TokenMetadata.
- tokenNames - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- TokenRelation - Class in org.apache.cassandra.cql3
-
A relation using the token function.
- TokenRelation(List<ColumnDefinition.Raw>, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TokenRelation
-
- TokenRestriction - Class in org.apache.cassandra.cql3.restrictions
-
Restriction
using the token function.
- TokenRestriction(CFMetaData, List<ColumnDefinition>) - 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 - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- Tokens - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- tokens - Variable in class org.apache.cassandra.dht.BootStrapper
-
- tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- tokens - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
-
- tokens - Variable in class org.apache.cassandra.index.sasi.sa.Term
-
- TOKENS_PER_BLOCK - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
-
- tokenSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
-
- TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
-
- TokenSerializer - Class in org.apache.cassandra.gms
-
- TokenSerializer() - Constructor for class org.apache.cassandra.gms.TokenSerializer
-
- tokensFromString(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- TokenTree - Class in org.apache.cassandra.index.sasi.disk
-
- TokenTree(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree
-
- TokenTree(Descriptor, MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree
-
- TokenTree.OnDiskToken - Class in org.apache.cassandra.index.sasi.disk
-
- TokenTree.TokenTreeIterator - Class in org.apache.cassandra.index.sasi.disk
-
- TokenTreeBuilder - Interface in org.apache.cassandra.index.sasi.disk
-
- TokenTreeBuilder.EntryType - Enum in org.apache.cassandra.index.sasi.disk
-
- toKeyExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
-
- toKeyIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
-
- toleratesErrorsInSection - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
-
- toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- tombstone(CFMetaData, ByteBuffer, ByteBuffer, long, int) - Static method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- tombstone(ColumnDefinition, long, int) - Static method in class org.apache.cassandra.db.rows.BufferCell
-
- tombstone(ColumnDefinition, long, int, CellPath) - Static method in class org.apache.cassandra.db.rows.BufferCell
-
- TOMBSTONE_COMPACTION_INTERVAL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstone_failure_threshold - Variable in class org.apache.cassandra.config.Config
-
- TOMBSTONE_HISTOGRAM_BIN_SIZE - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- TOMBSTONE_HISTOGRAM_SPOOL_SIZE - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- TOMBSTONE_HISTOGRAM_TTL_ROUND_SECONDS - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- TOMBSTONE_THRESHOLD_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstone_warn_threshold - Variable in class org.apache.cassandra.config.Config
-
- tombstoneCompactionInterval - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstoneOption() - Method in class org.apache.cassandra.schema.CompactionParams
-
- TombstoneOverwhelmingException - Exception in org.apache.cassandra.db.filter
-
- TombstoneOverwhelmingException(int, String, CFMetaData, DecoratedKey, ClusteringPrefix) - Constructor for exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
-
- tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Tombstones scanned in queries on this Keyspace
- tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Tombstones scanned in queries on this CF
- tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- TOOL_NAME - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- toolInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- toolInitialization(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Initializes this class as a tool, which means that the configuration is loaded
using
DatabaseDescriptor.loadConfig()
and all non-daemon configuration parts will be setup.
- TOP - Static variable in class org.apache.cassandra.db.ClusteringBound
-
The biggest end bound, i.e.
- TOP - Static variable in class org.apache.cassandra.db.LegacyLayout.LegacyBound
-
- TOP - Static variable in class org.apache.cassandra.db.rows.CellPath
-
- topK - Variable in class org.apache.cassandra.utils.TopKSampler.SamplerResult
-
- TopKSampler<T> - Class in org.apache.cassandra.utils
-
- TopKSampler() - Constructor for class org.apache.cassandra.utils.TopKSampler
-
- TopKSampler.SamplerResult<S> - Class in org.apache.cassandra.utils
-
Represents the cardinality and the topK ranked items collected during a
sample period
- TopPartitions - Class in org.apache.cassandra.tools.nodetool
-
- TopPartitions() - Constructor for class org.apache.cassandra.tools.nodetool.TopPartitions
-
- toRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
-
Converts this Relation
into a Restriction
.
- toRowIterator(CFMetaData, DecoratedKey, Iterator<LegacyLayout.LegacyCell>, int) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- toSelectables(List<RawSelector>, CFMetaData) - Static method in class org.apache.cassandra.cql3.selection.RawSelector
-
Converts the specified list of RawSelector
s into a list of Selectable
s.
- toShort(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to a short.
- toSilentException(ProtocolException) - Static method in exception org.apache.cassandra.transport.ProtocolException
-
- toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- toString() - Method in class org.apache.cassandra.auth.CassandraPrincipal
-
Return a string representation of this CassPrincipal
.
- toString() - Method in class org.apache.cassandra.auth.DataResource
-
- toString() - Method in class org.apache.cassandra.auth.FunctionResource
-
- toString() - Method in class org.apache.cassandra.auth.JMXResource
-
- toString() - Method in class org.apache.cassandra.auth.PermissionDetails
-
- toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
-
Deprecated.
- toString() - Method in class org.apache.cassandra.auth.RoleOptions
-
- toString() - Method in class org.apache.cassandra.auth.RoleResource
-
- toString() - Method in class org.apache.cassandra.cache.CounterCacheKey
-
- toString() - Method in class org.apache.cassandra.cache.KeyCacheKey
-
- toString() - Method in class org.apache.cassandra.cache.RowCacheKey
-
- toString() - Method in class org.apache.cassandra.config.CFMetaData.DroppedColumn
-
- toString() - Method in class org.apache.cassandra.config.CFMetaData
-
- toString() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toString() - Method in class org.apache.cassandra.config.ParameterizedClass
-
- toString() - Method in class org.apache.cassandra.config.ViewDefinition
-
- toString() - Method in class org.apache.cassandra.cql3.CFName
-
- toString() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- toString() - Method in class org.apache.cassandra.cql3.ColumnSpecification
-
- toString() - Method in class org.apache.cassandra.cql3.Constants.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.Duration
-
- toString() - Method in class org.apache.cassandra.cql3.FieldIdentifier
-
- toString() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- toString() - Method in class org.apache.cassandra.cql3.functions.FunctionName
-
- toString() - Method in class org.apache.cassandra.cql3.IndexName
-
- toString() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ElementAddition
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ElementSubtraction
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetField
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- toString() - Method in enum org.apache.cassandra.cql3.Operator
-
- toString() - Method in class org.apache.cassandra.cql3.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.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.TermSlice
-
- 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 class org.apache.cassandra.cql3.selection.Selectable.WithCast
-
- 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.WithTerm
-
- toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
-
- 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.SingleColumnRelation
-
- toString() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- toString() - Method in class org.apache.cassandra.cql3.statements.AlterViewStatement
-
- toString() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- toString() - Method in enum org.apache.cassandra.cql3.statements.IndexTarget.Type
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- toString() - Method in class org.apache.cassandra.cql3.Term.Raw
-
- toString() - Method in class org.apache.cassandra.cql3.TokenRelation
-
- toString() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- toString() - Method in class org.apache.cassandra.cql3.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.db.ClockAndCount
-
- toString(CFMetaData) - Method in interface org.apache.cassandra.db.Clustering
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- toString(ClusteringComparator) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary
-
- toString() - Method in class org.apache.cassandra.db.ClusteringComparator
-
- toString(CFMetaData) - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Generates a proper string representation of the prefix.
- toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- toString() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
-
- toString() - Method in class org.apache.cassandra.db.Columns
-
- toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
-
- toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- toString() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
-
- toString() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- toString() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- toString() - Method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
-
- toString() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
-
- toString() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- toString() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- toString() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- toString() - Method in enum org.apache.cassandra.db.compaction.OperationType
-
- toString() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- toString() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- toString() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- toString(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Human-readable String from context.
- toString() - Method in class org.apache.cassandra.db.CounterMutation
-
- toString(boolean) - Method in class org.apache.cassandra.db.CounterMutation
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.DataRange
-
- toString() - Method in class org.apache.cassandra.db.DecoratedKey
-
- toString() - Method in class org.apache.cassandra.db.DeletionTime
-
- toString() - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- toString() - Method in class org.apache.cassandra.db.DiskBoundaries
-
- toString(CFMetaData) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
-
- toString() - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
- toString() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
-
- toString() - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
-
- toString() - Method in class org.apache.cassandra.db.filter.RowFilter
-
- toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
-
- toString() - Method in class org.apache.cassandra.db.Keyspace
-
- toString() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyBound
-
- toString() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- toString() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyCellName
-
- toString() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstone
-
- toString() - Method in class org.apache.cassandra.db.LegacyLayout.LegacyRangeTombstoneList
-
- toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
-
- toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- toString() - Method in class org.apache.cassandra.db.lifecycle.LogReplicaSet
-
- toString() - Method in class org.apache.cassandra.db.lifecycle.View
-
- toString() - Method in class org.apache.cassandra.db.LivenessInfo
-
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- toString() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
This must be overriden by subclasses if necessary so that for any
AbstractType, this == TypeParser.parse(toString()).
- toString() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- toString() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- toString() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- toString() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.ListType
-
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.MapType
-
- toString() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- toString() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.SetType
-
- toString() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- toString() - Method in class org.apache.cassandra.db.marshal.UserType
-
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.UserType
-
- toString() - Method in class org.apache.cassandra.db.Memtable
-
- toString() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
- toString() - Method in class org.apache.cassandra.db.Mutation
-
- toString(boolean) - Method in class org.apache.cassandra.db.Mutation
-
- toString() - Method in class org.apache.cassandra.db.PartitionColumns
-
- 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
-
- toString(ClusteringComparator) - Method in class org.apache.cassandra.db.RangeTombstone
-
- toString() - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- toString(CFMetaData, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- toString(CFMetaData, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- toString() - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- toString(CFMetaData, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- toString(CFMetaData, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- toString() - Method in class org.apache.cassandra.db.rows.EncodingStats
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
- toString() - Method in class org.apache.cassandra.db.rows.Row.Deletion
-
- toString(CFMetaData, boolean) - Method in interface org.apache.cassandra.db.rows.Row
-
- toString(CFMetaData) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
- toString(CFMetaData, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
- toString(CFMetaData, boolean, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
- toString() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
-
- toString() - Method in class org.apache.cassandra.db.SerializationHeader.Component
-
- toString() - Method in class org.apache.cassandra.db.SerializationHeader
-
- toString() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
-
- toString() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
- toString(CFMetaData) - Method in class org.apache.cassandra.db.Slice
-
- toString(ClusteringComparator) - Method in class org.apache.cassandra.db.Slice
-
- toString() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- toString() - Method in class org.apache.cassandra.db.Truncation
-
- toString() - Method in class org.apache.cassandra.dht.Bounds
-
- toString() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- toString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- toString() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- toString() - Method in class org.apache.cassandra.dht.Range
-
- toString() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- toString(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- toString() - Method in class org.apache.cassandra.gms.EndpointState
-
- toString() - Method in class org.apache.cassandra.gms.FailureDetector
-
- toString() - Method in class org.apache.cassandra.gms.GossipDigest
-
- toString() - Method in class org.apache.cassandra.gms.VersionedValue
-
- toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- toString() - Method in class org.apache.cassandra.index.sasi.disk.Descriptor.Version
-
- toString() - Method in class org.apache.cassandra.index.sasi.plan.Expression
-
- toString() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
-
- toString() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- toString() - Method in error org.apache.cassandra.io.FSDiskFullWriteError
-
- toString() - Method in error org.apache.cassandra.io.FSReadError
-
- toString() - Method in error org.apache.cassandra.io.FSWriteError
-
- toString() - Method in class org.apache.cassandra.io.sstable.Component
-
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- toString() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- toString() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- toString() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
-
- toString() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- toString() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
-
- toString() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
-
- toString() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- toString() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
-
- toString() - Method in class org.apache.cassandra.io.util.FileHandle
-
- toString() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
-
- toString() - Method in class org.apache.cassandra.io.util.Memory
-
- toString(long, long) - Static method in class org.apache.cassandra.io.util.Memory
-
- toString() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- toString() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
-
- toString() - Method in class org.apache.cassandra.locator.InetAddressAndPort
-
- toString(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
-
- toString() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- toString() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- toString() - Method in class org.apache.cassandra.net.CallbackInfo
-
- toString() - Method in class org.apache.cassandra.net.MessageIn
-
- toString() - Method in class org.apache.cassandra.net.MessageOut
-
- toString() - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest
-
- toString() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- toString() - Method in class org.apache.cassandra.repair.messages.SyncRequest
-
- toString() - Method in class org.apache.cassandra.repair.messages.ValidationRequest
-
- toString() - Method in class org.apache.cassandra.repair.RepairJobDesc
-
- toString() - Method in enum org.apache.cassandra.repair.RepairParallelism
-
- toString() - Method in enum org.apache.cassandra.schema.CachingParams.Option
-
- toString() - Method in class org.apache.cassandra.schema.CachingParams
-
- 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.Functions
-
- toString() - Method in class org.apache.cassandra.schema.Indexes
-
- toString() - Method in class org.apache.cassandra.schema.IndexMetadata
-
- toString() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- toString() - Method in enum org.apache.cassandra.schema.KeyspaceParams.Option
-
- toString() - Method in class org.apache.cassandra.schema.KeyspaceParams
-
- toString() - Method in class org.apache.cassandra.schema.Keyspaces
-
- toString() - Method in class org.apache.cassandra.schema.ReplicationParams
-
- toString() - Method in class org.apache.cassandra.schema.SpeculativeRetryParam
-
- 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.Views
-
- toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- toString(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- toString(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- toString(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- toString(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- toString(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
-
- toString(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- toString(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- toString(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- toString(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- toString(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- toString(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- toString(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- toString(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- toString(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- toString(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- toString(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- toString(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- toString(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- toString(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- toString(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- toString() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- toString() - Method in enum org.apache.cassandra.service.CacheService.CacheType
-
- toString() - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
-
- toString() - Method in class org.apache.cassandra.service.pager.PagingState
-
- toString() - Method in class org.apache.cassandra.service.paxos.Commit
-
- toString() - Method in class org.apache.cassandra.service.paxos.PrepareResponse
-
- toString() - Method in class org.apache.cassandra.service.SSTablesVersionsInUseChangeNotification
-
- toString() - Method in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- toString() - Method in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.KeepAliveMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- toString() - Method in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- toString() - Method in class org.apache.cassandra.streaming.ProgressInfo
-
- toString() - Method in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
-
- toString() - Method in class org.apache.cassandra.streaming.StreamSummary
-
- toString() - Method in class org.apache.cassandra.transport.Event.SchemaChange
-
- toString() - Method in class org.apache.cassandra.transport.Event.StatusChange
-
- toString() - Method in class org.apache.cassandra.transport.Event.TopologyChange
-
- toString() - Method in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.BatchMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.EventMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.OptionsMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.QueryMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ReadyMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.RegisterMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- toString() - Method in class org.apache.cassandra.transport.messages.StartupMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.SupportedMessage
-
- toString() - Method in enum org.apache.cassandra.transport.ProtocolVersion
-
- toString() - Method in class org.apache.cassandra.utils.BloomCalculations.BloomSpecification
-
- toString() - Method in class org.apache.cassandra.utils.BloomFilter
-
- toString() - Method in class org.apache.cassandra.utils.CassandraVersion
-
- toString() - Method in class org.apache.cassandra.utils.CounterId
-
- toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Make straing out of the given Map
.
- toString() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
- toString() - Method in class org.apache.cassandra.utils.IntegerInterval
-
- toString() - Method in class org.apache.cassandra.utils.Interval
-
- toString() - Method in class org.apache.cassandra.utils.IntervalTree
-
- toString() - Method in class org.apache.cassandra.utils.MD5Digest
-
- toString() - Method in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- toString() - Method in class org.apache.cassandra.utils.MerkleTree
-
- toString() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- toString() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- toString() - Method in class org.apache.cassandra.utils.Pair
-
- toString() - Method in class org.apache.cassandra.utils.RecomputingSupplier
-
- toStringUTC(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- toSuperColumnAdapter() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- toSuperColumnAdapter() - Method in class org.apache.cassandra.cql3.Relation
-
Required for SuperColumn compatibility, creates an adapter Relation that remaps all restrictions required for
SuperColumn tables.
- toSuperColumnAdapter() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- total(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the aggregated count across all counter ids.
- totalBlocked - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of tasks that had blocked before being accepted (or rejected).
- totalBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of tasks that had blocked before being accepted (or rejected).
- totalBlockFor() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- totalBlockFor() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- totalBlockFor() - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- totalBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- totalCommitLogSize - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Current size used by all the commit log segments
- totalCompactionsCompleted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Total number of compactions since server [re]start
- totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Total disk space used by SSTables belonging to this CF, including obsolete ones waiting to be GC'd
- totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Total disk space used by SSTables belonging to this table, including obsolete ones waiting to be GC'd
- totalEndpoints() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- totalEndpoints() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
-
- totalHints - Static variable in class org.apache.cassandra.metrics.StorageMetrics
-
- totalHintsInProgress - Static variable in class org.apache.cassandra.metrics.StorageMetrics
-
- totalIncomingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- totalLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Total latency in micro sec
- totalOutgoingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- totalRows() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- totalSize() - Method in class org.apache.cassandra.streaming.StreamReader
-
- totalSize - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- totalSize() - Method in class org.apache.cassandra.streaming.StreamWriter
-
- totalTimeouts - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Total number of timeouts happened on this node
- toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
-
Converts the specified Raw
into a Term
.
- toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
-
- toTerms(List<? extends ColumnSpecification>, List<? extends Term.Raw>, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
-
Converts the specified Raw
terms into a Term
s.
- toThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(RequestValidationException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(UnavailableException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(AuthenticationException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(RequestTimeoutException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(RequestFailureException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(KeyspaceMetadata) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(CFMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThriftPreparedResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toThriftResult() - Method in class org.apache.cassandra.cql3.ResultSet
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
-
- toUnfilteredRowIterator(CFMetaData, DecoratedKey, LegacyLayout.LegacyDeletionInfo, Iterator<LegacyLayout.LegacyCell>) - Static method in class org.apache.cassandra.db.LegacyLayout
-
- toWriteUTFBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- tProtocolFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- TpStats - Class in org.apache.cassandra.tools.nodetool
-
- TpStats() - Constructor for class org.apache.cassandra.tools.nodetool.TpStats
-
- TpStatsHolder - Class in org.apache.cassandra.tools.nodetool.stats
-
- TpStatsHolder(NodeProbe) - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsHolder
-
- TpStatsPrinter - Class in org.apache.cassandra.tools.nodetool.stats
-
- TpStatsPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter
-
- TpStatsPrinter.DefaultPrinter - Class in org.apache.cassandra.tools.nodetool.stats
-
- trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object[]) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(ByteBuffer, String, int) - Method in class org.apache.cassandra.tracing.Tracing
-
Called from
OutboundTcpConnection
for non-local traces (traces
that are not initiated by local node == coordinator).
- TRACE_HEADER - Static variable in class org.apache.cassandra.tracing.Tracing
-
- TRACE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- TRACE_KEYSPACE_NAME - Static variable in class org.apache.cassandra.config.SchemaConstants
-
- trace_next_query() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- TRACE_TYPE - Static variable in class org.apache.cassandra.tracing.Tracing
-
- 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
-
- traceNextQuery() - Method in class org.apache.cassandra.service.QueryState
-
- traceRepair(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
-
- traceState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
-
- traceState - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- TraceState - Class in org.apache.cassandra.tracing
-
ThreadLocal state for a tracing session.
- TraceState(InetAddress, UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceState
-
- TraceState.Status - Enum in org.apache.cassandra.tracing
-
- TraceStateImpl - Class in org.apache.cassandra.tracing
-
ThreadLocal state for a tracing session.
- TraceStateImpl(InetAddress, UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceStateImpl
-
- traceType - Variable in class org.apache.cassandra.tracing.TraceState
-
- tracetype_query_ttl - Variable in class org.apache.cassandra.config.Config
-
- tracetype_repair_ttl - Variable in class org.apache.cassandra.config.Config
-
- Tracing - Class in org.apache.cassandra.tracing
-
A trace session context.
- Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
-
- Tracing.TraceType - Enum in org.apache.cassandra.tracing
-
- tracingId - Variable in class org.apache.cassandra.transport.Message.Response
-
- tracingRequested - Variable in class org.apache.cassandra.transport.Message.Request
-
- trackedByCDC() - Method in class org.apache.cassandra.db.Mutation
-
- TrackedDataInputPlus - Class in org.apache.cassandra.io.util
-
This class is to track bytes read from given DataInput
- TrackedDataInputPlus(DataInput) - Constructor for class org.apache.cassandra.io.util.TrackedDataInputPlus
-
- TrackedInputStream - Class in org.apache.cassandra.io.util
-
This class is to track bytes read from given DataInputStream
- TrackedInputStream(InputStream) - Constructor for class org.apache.cassandra.io.util.TrackedInputStream
-
- tracker - Variable in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- Tracker - Class in org.apache.cassandra.db.lifecycle
-
Tracker tracks live
View
of data store for a table.
- Tracker(Memtable, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.Tracker
-
- tracker - Variable in class org.apache.cassandra.transport.SimpleClient
-
- 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
-
- tracksLegacyCounterShards() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- transaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- Transactional - Interface in org.apache.cassandra.utils.concurrent
-
An abstraction for Transactional behaviour.
- Transactional.AbstractTransactional - Class in org.apache.cassandra.utils.concurrent
-
A simple abstract implementation of Transactional behaviour.
- Transactional.AbstractTransactional.State - Enum in org.apache.cassandra.utils.concurrent
-
- TransactionalProxy() - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
-
- TransactionalProxy() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
-
- TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
-
- TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
-
- transferFiles(InetAddress, Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- transferFiles(InetAddress, Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send given SSTable files.
- 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(InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send data of specific columnFamilies
under keyspace
and ranges
.
- transferRanges(InetAddress, InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send data of specific keyspace and ranges.
- transferRanges(InetAddress, InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send data of specific columnFamilies
under keyspace
and ranges
.
- TRANSFERRED_RANGES - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- transferredRangesPerKeyspace - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- transferredRangesPerKeyspace - Variable in class org.apache.cassandra.streaming.StreamSession
-
- transfers - Variable in class org.apache.cassandra.streaming.StreamSession
-
- transferTo(long, long, WritableByteChannel) - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- transformAndFilter(Object[], Function<? super V, ? extends V>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Takes a btree and transforms it using the provided function, filtering out any null results.
- Transformation<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.transform
-
We have a single common superclass for all Transformations to make implementation efficient.
- Transformation() - Constructor for class org.apache.cassandra.db.transform.Transformation
-
- transparent_data_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- TransparentDataEncryptionOptions - Class in org.apache.cassandra.config
-
- TransparentDataEncryptionOptions() - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- TransparentDataEncryptionOptions(boolean) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- TransparentDataEncryptionOptions(String, String, ParameterizedClass) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- TransparentDataEncryptionOptions(boolean, String, String, ParameterizedClass) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
-
- TransportException - Interface in org.apache.cassandra.exceptions
-
- traverse(Cursor<? super K, ? super V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
-
Traverses the
Trie
in lexicographical order.
- tree - Variable in class org.apache.cassandra.utils.btree.BTreeSet
-
- tree() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- TreeDifference(Token, Token, byte) - Constructor for class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- treeIndexOfBranchKey(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- treeIndexOffsetOfChild(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- treeIndexOfKey(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
tree index => index of key wrt all items in the tree laid out serially
This version of the method permits requesting out-of-bounds indexes, -1 and size
- treeIndexOfLeafKey(int) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- treeMaxToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- treeMinToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
-
- TreeResponse - Class in org.apache.cassandra.repair
-
Merkle tree response sent from given endpoint.
- TreeResponse(InetAddress, MerkleTrees) - Constructor for class org.apache.cassandra.repair.TreeResponse
-
- trees - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
Merkle hash tree response.
- trees - Variable in class org.apache.cassandra.repair.TreeResponse
-
- treesReceived(MerkleTrees) - Method in class org.apache.cassandra.repair.ValidationTask
-
Receive MerkleTrees from replica node.
- trickle_fsync - Variable in class org.apache.cassandra.config.Config
-
- trickle_fsync_interval_in_kb - Variable in class org.apache.cassandra.config.Config
-
- trickleFsync(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
-
- trickleFsync() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
-
- trickleFsyncByteInterval(int) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
-
- trickleFsyncByteInterval() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
-
- Trie<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
-
Defines the interface for a prefix tree, an ordered tree data structure.
- TrieMemIndex - Class in org.apache.cassandra.index.sasi.memory
-
- TrieMemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.TrieMemIndex
-
- TrieMemIndex.ConcurrentPrefixTrie - Class in org.apache.cassandra.index.sasi.memory
-
- TrieMemIndex.ConcurrentSuffixTrie - Class in org.apache.cassandra.index.sasi.memory
-
- Tries - Class in org.apache.cassandra.index.sasi.utils.trie
-
A collection of
Trie
utilities
- Tries() - Constructor for class org.apache.cassandra.index.sasi.utils.trie.Tries
-
- trigger() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
-
- TriggerExecutor - Class in org.apache.cassandra.triggers
-
- TriggerMetadata - Class in org.apache.cassandra.schema
-
- TriggerMetadata(String, String) - Constructor for class org.apache.cassandra.schema.TriggerMetadata
-
- triggers(Triggers) - Method in class org.apache.cassandra.config.CFMetaData
-
- TRIGGERS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Triggers - Class in org.apache.cassandra.schema
-
- Triggers.Builder - Class in org.apache.cassandra.schema
-
- trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
-
- trim() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- trimTrailingZeros() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Lowers numWords, the number of words in use,
by checking for trailing zero words.
- trivialReduceIsTrivial() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- trueInclusive - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SuperColumnMultiSliceRestriction
-
- trueSnapshotsSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- trueSnapshotsSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- trueSnapshotsSize() - Method in class org.apache.cassandra.db.Directories
-
- trueSnapshotsSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Disk space used by snapshot files which
- trueSnapshotsSize() - Method in class org.apache.cassandra.service.StorageService
-
- trueSnapshotsSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the true size taken by all snapshots across all keyspaces.
- trueSnapshotsSize() - Method in class org.apache.cassandra.tools.NodeProbe
-
- truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- truncate(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- truncate() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
- truncate(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- truncate(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Truncates (deletes) the given table from the provided keyspace.
- truncate(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- truncate_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- truncateAllHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
Deprecated.
- truncateAllHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
Deprecated.
Truncate all the hints
- truncateAllIndexesBlocking(long) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Truncate all indexes
- truncateBlocking() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- truncateBlocking(CommitLogPosition, long) - Method in class org.apache.cassandra.db.view.TableViews
-
- truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the truncate operatoin, which effectively deletes all data from
the column family cfname
- 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(Throwable) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
-
- TruncateException(String) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
-
- truncateHints(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- truncateHints() - Method in class org.apache.cassandra.tools.NodeProbe
-
- TruncateHints - Class in org.apache.cassandra.tools.nodetool
-
- TruncateHints() - Constructor for class org.apache.cassandra.tools.nodetool.TruncateHints
-
- TruncateResponse - Class in org.apache.cassandra.db
-
This message is sent back the truncate operation and basically specifies if
the truncate succeeded.
- TruncateResponse(String, String, boolean) - Constructor for class org.apache.cassandra.db.TruncateResponse
-
- TruncateResponse.TruncateResponseSerializer - Class in org.apache.cassandra.db
-
- TruncateResponseHandler - Class in org.apache.cassandra.service
-
- TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
-
- TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- truncateStatement() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- truncateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- TruncateStatement - Class in org.apache.cassandra.cql3.statements
-
- TruncateStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.TruncateStatement
-
- TruncateVerbHandler - Class in org.apache.cassandra.db
-
- TruncateVerbHandler() - Constructor for class org.apache.cassandra.db.TruncateVerbHandler
-
- Truncation - Class in org.apache.cassandra.db
-
A truncate operation descriptor
- Truncation(String, String) - Constructor for class org.apache.cassandra.db.Truncation
-
- TruncationNotification - Class in org.apache.cassandra.notifications
-
Fired during truncate, after the memtable has been flushed but before any
snapshot is taken and SSTables are discarded
- TruncationNotification(long) - Constructor for class org.apache.cassandra.notifications.TruncationNotification
-
- truststore - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- TRUSTSTORE - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- TRUSTSTORE_PASSWORD - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- tryAllocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
-
- tryAllocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
-
- tryAllocate(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
-
Attempts to allocate an amount of permits from this limit.
- tryAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- tryCloseFD(int) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- tryComponentFromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
- tryFcntl(int, int, int) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- tryGet(int) - Static method in class org.apache.cassandra.utils.memory.BufferPool
-
Unlike the get methods, this will return null if the pool is exhausted
- tryIntervalLock(long) - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
-
Try acquiring a write lock if the given interval is passed since the last call to this method.
- tryMlockall() - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- tryModify(SSTableReader, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- tryModify(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- tryRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- tryRef() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- tryRef() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
-
- tryRef(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Attempt to take a reference to the provided object; if it has already been released, null will be returned
- tryRef(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
Acquire a reference to all of the provided objects, or none
- trySkipCache(String, long, long) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- trySkipCache(int, long, long, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- trySkipCache(int, long, int, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- trySync(int) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
- trySync(int) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- trySyncDir(File) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- tryToComputeNext() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
-
- tryToComputeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
-
- tryUncacheRead() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
-
- tryUpcast(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.index.sasi.utils.TypeUtil
-
- TServerCustomFactory - Class in org.apache.cassandra.thrift
-
Helper implementation to create a thrift TServer based on one of the common types we support (sync, hsha),
or a custom type by setting the fully qualified java class name in the rpc_server_type setting.
- TServerCustomFactory(String) - Constructor for class org.apache.cassandra.thrift.TServerCustomFactory
-
- TServerFactory - Interface in org.apache.cassandra.thrift
-
- TServerFactory.Args - Class in org.apache.cassandra.thrift
-
- ttl - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- ttl() - Method in class org.apache.cassandra.db.LivenessInfo
-
- ttl(int) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
-
Sets the ttl to use for the following additions to this builder or any derived (update or row) builder.
- ttl(int) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
-
Sets the ttl to use for the following additions to this builder or any derived (row) builder.
- ttl() - Method in class org.apache.cassandra.db.rows.BufferCell
-
- ttl() - Method in class org.apache.cassandra.db.rows.Cell
-
The cell ttl.
- ttl() - Method in class org.apache.cassandra.db.rows.NativeCell
-
- ttl(int) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Sets the ttl to use for the following additions.
- ttl - Variable in class org.apache.cassandra.tracing.TraceState
-
- ttlSerializedSize(int) - Method in class org.apache.cassandra.db.SerializationHeader
-
- ttlTracker - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- tuple(List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- tuple_type() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- tuple_type() - Method in class org.apache.cassandra.cql3.CqlParser
-
- tupleLiteral() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- tupleLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
-
- tupleOfIdentifiers() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- tupleOfIdentifiers() - Method in class org.apache.cassandra.cql3.CqlParser
-
- tupleOfMarkersForTuples() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- tupleOfMarkersForTuples() - Method in class org.apache.cassandra.cql3.CqlParser
-
- tupleOfTupleLiterals() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- tupleOfTupleLiterals() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Tuples - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for tuples.
- Tuples.DelayedValue - Class in org.apache.cassandra.cql3
-
Similar to Value, but contains at least one NonTerminal, such as a non-pure functions or bind marker.
- Tuples.InMarker - Class in org.apache.cassandra.cql3
-
Represents a marker for a set of IN values that are tuples, like "SELECT ...
- Tuples.INRaw - Class in org.apache.cassandra.cql3
-
A raw marker for an IN list of tuples, like "SELECT ...
- Tuples.InValue - Class in org.apache.cassandra.cql3
-
A terminal value for a list of IN values that are tuples.
- Tuples.Literal - Class in org.apache.cassandra.cql3
-
A raw, literal tuple.
- Tuples.Marker - Class in org.apache.cassandra.cql3
-
{@code
Represents a marker for a single tuple, like "SELECT ...
- Tuples.Raw - Class in org.apache.cassandra.cql3
-
A raw placeholder for a tuple of values for different multiple columns, each of which may have a different type.
- Tuples.Value - Class in org.apache.cassandra.cql3
-
A tuple of terminal values (e.g (123, 'abc')).
- TupleSerializer - Class in org.apache.cassandra.serializers
-
- TupleSerializer(List<TypeSerializer<?>>) - Constructor for class org.apache.cassandra.serializers.TupleSerializer
-
- tupleToString(List<?>) - Static method in class org.apache.cassandra.cql3.Tuples
-
- TupleType - Class in org.apache.cassandra.db.marshal
-
This is essentially like a CompositeType, but it's not primarily meant for comparison, just
to pack multiple values together so has a more friendly encoding.
- TupleType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.TupleType
-
- TupleType(List<AbstractType<?>>, boolean) - Constructor for class org.apache.cassandra.db.marshal.TupleType
-
- TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- twoHourRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Returns the two-hour rate in terms of events per second.
- txn - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- txnProxy() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- txnProxy() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- txnProxy - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- txnProxy() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- txnProxy() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- txnProxy() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- type - Variable in class org.apache.cassandra.config.CFMetaData.DroppedColumn
-
- type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
-
- type - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- type - Variable in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- type - Variable in enum org.apache.cassandra.db.compaction.OperationType
-
- type(int) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- type() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
-
- type() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
-
- type - Variable in class org.apache.cassandra.io.sstable.Component
-
- type - Variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- type - Variable in class org.apache.cassandra.transport.Event
-
- type - Variable in class org.apache.cassandra.transport.Frame.Header
-
- type - Variable in class org.apache.cassandra.transport.Message
-
- TYPE_NAME - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
- TYPE_NAME - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- TypeCast - Class in org.apache.cassandra.cql3
-
- TypeCast(CQL3Type.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TypeCast
-
- typeColumns(CreateTypeStatement) - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- typeColumns(CreateTypeStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- typeHashCode(AbstractType<?>) - Static method in class org.apache.cassandra.schema.Functions
-
- typeHashCode(List<AbstractType<?>>) - Static method in class org.apache.cassandra.schema.Functions
-
- typeOf(ByteBuffer) - Static method in enum org.apache.cassandra.io.compress.BufferType
-
- TypeParser - Class in org.apache.cassandra.db.marshal
-
Parse a string containing an Type definition.
- TypeParser(String) - Constructor for class org.apache.cassandra.db.marshal.TypeParser
-
- types - Variable in class org.apache.cassandra.db.marshal.CompositeType
-
- types - Variable in class org.apache.cassandra.db.marshal.TupleType
-
- types - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
-
- TYPES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Types - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's UDTs.
- Types.Builder - Class in org.apache.cassandra.schema
-
- Types.RawBuilder - Class in org.apache.cassandra.schema
-
- TypeSerializer<T> - Interface in org.apache.cassandra.serializers
-
- TypeSizes - Class in org.apache.cassandra.db
-
- typesMatch(AbstractType<?>, AbstractType<?>) - Static method in class org.apache.cassandra.schema.Functions
-
- typesMatch(List<AbstractType<?>>, List<AbstractType<?>>) - Static method in class org.apache.cassandra.schema.Functions
-
- typeTokens(TypeCodec<Object>[], boolean) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
Construct an array containing the Java classes for the given Java Driver DataType
s.
- TypeUtil - Class in org.apache.cassandra.index.sasi.utils
-
- TypeUtil() - Constructor for class org.apache.cassandra.index.sasi.utils.TypeUtil
-
- V - Static variable in class org.apache.cassandra.cql3.Cql_Lexer
-
- V - Static variable in class org.apache.cassandra.cql3.Cql_Parser
-
- V - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- V - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- validate() - Method in class org.apache.cassandra.auth.RoleOptions
-
Validate the contents of the options in two ways:
- Ensure that only a subset of the options supported by the configured IRoleManager are set
- Validate the type of any option values present.
- validate() - Method in class org.apache.cassandra.config.CFMetaData
-
- validate() - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- validate(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform additional validation required by the statment.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterViewStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.CFProperties
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateViewStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropViewStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- validate() - Method in class org.apache.cassandra.cql3.statements.KeyspaceAttributes
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.TableAttributes
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- validate(ClusteringPrefix) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Validates the provided prefix for corrupted data.
- validate() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- validate() - Method in class org.apache.cassandra.db.LivenessInfo
-
Validate the data contained by this liveness information.
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
-
- validate() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Validates the data contained in this update.
- validate() - Method in class org.apache.cassandra.db.rows.AbstractCell
-
- validate() - Method in class org.apache.cassandra.db.rows.ColumnData
-
Validate the column data.
- validate() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
-
- validate(UnfilteredPartitionIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
-
- validate(UnfilteredRowIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
-
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- validate(PartitionUpdate) - Method in interface org.apache.cassandra.index.Index
-
Called at write time to ensure that values present in the update
are valid according to the rules of all registered indexes which
will process it.
- validate(ReadCommand) - Method in interface org.apache.cassandra.index.Index
-
Used to validate the various parameters of a supplied ReadCommand,
this is called prior to execution.
- validate(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- validate(PartitionUpdate) - Method in class org.apache.cassandra.index.internal.CassandraIndex
-
- validate(Map<String, String>, ColumnDefinition) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
-
- validate(Map<String, String>, ColumnDefinition) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
-
- validate(PartitionUpdate) - Method in class org.apache.cassandra.index.sasi.SASIIndex
-
- validate(PartitionUpdate) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Called at write time to ensure that values present in the update
are valid according to the rules of all registered indexes which
will process it.
- validate(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
- validate(String) - Static method in class org.apache.cassandra.io.sstable.format.Version
-
- validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- validate() - 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(CFMetaData) - Method in class org.apache.cassandra.schema.IndexMetadata
-
- validate() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
-
- validate(String) - Method in class org.apache.cassandra.schema.KeyspaceParams
-
- validate(String) - Method in class org.apache.cassandra.schema.ReplicationParams
-
- validate() - Method in class org.apache.cassandra.schema.TableParams
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.AsciiSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DurationSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TupleSerializer
-
- validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UserTypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UTF8Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- validateAnalyzer(Map<String, String>, ColumnDefinition) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
-
- validateCell(Cell) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- validateCell(Cell) - Method in class org.apache.cassandra.db.marshal.UserType
-
- validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Validate cell value.
- validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative validation function used by CollectionsType in conjunction with CompositeType.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validateColumnData(CFMetaData, ByteBuffer, Column) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
Validates the data part of the column (everything in the column object but the name, which is assumed to be valid)
- validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnFamilyWithCompactMode(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnOrSuperColumn(CFMetaData, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnParent(CFMetaData, ColumnParent) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnPath(CFMetaData, ColumnPath) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
validates all parts of the path to the column, including the column name
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Like getComparator, but validates that @param i does not exceed the defined range
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- validateCompatibility(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateCompressionLevel(String) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- validateCompressorType(String) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Validates configuration of IAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Validates configuration of IAuthorizer implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Validates configuration of IInternodeAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Hook to perform validation of an implementation's configuration (if supported).
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateData(CFMetaData) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
-
- validateData(CFMetaData) - Method in class org.apache.cassandra.db.rows.AbstractRow
-
- validateData(CFMetaData) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
Validate the data of this atom.
- validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForCasCommit(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForIndexing() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Deprecated.
- validateForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validateForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- validateForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- validateForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- validateForRead(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForWrite(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateIfFixedSize(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspace(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotSystem(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotYetExisting(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateLogin() - Method in class org.apache.cassandra.service.ClientState
-
- validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
-
- validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateNewMessage(Message.Type, ProtocolVersion, int) - Method in class org.apache.cassandra.transport.ServerConnection
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
Deprecated.
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- validateOptions(Map<String, String>, CFMetaData) - Static method in class org.apache.cassandra.index.sasi.SASIIndex
-
- validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- validatePartitioner(Collection<? extends AbstractBounds<?>>) - Static method in class org.apache.cassandra.net.MessagingService
-
- validatePartitioner(AbstractBounds<?>) - Static method in class org.apache.cassandra.net.MessagingService
-
- validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateReallocation(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateTransportsCanStart() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- ValidationComplete - Class in org.apache.cassandra.repair.messages
-
ValidationComplete message is sent when validation compaction completed successfully.
- ValidationComplete(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- ValidationComplete(RepairJobDesc, MerkleTrees) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- validationComplete(RepairJobDesc, InetAddress, MerkleTrees) - Method in class org.apache.cassandra.repair.RepairSession
-
Receive merkle tree response or failed response from endpoint
for current repair job.
- ValidationMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata component used only for validating SSTable.
- ValidationMetadata(String, double) - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- ValidationMetadata.ValidationMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
- ValidationMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- ValidationRequest - Class in org.apache.cassandra.repair.messages
-
ValidationRequest
- ValidationRequest(RepairJobDesc, int) - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest
-
- ValidationRequest.ValidationRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- ValidationRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- ValidationTask - Class in org.apache.cassandra.repair
-
- ValidationTask(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.ValidationTask
-
- validator - Variable in class org.apache.cassandra.index.sasi.plan.Expression
-
- Validator - Class in org.apache.cassandra.repair
-
Handles the building of a merkle tree for a column family.
- Validator(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.Validator
-
- Validator(RepairJobDesc, InetAddress, int, boolean) - Constructor for class org.apache.cassandra.repair.Validator
-
- validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- validForReadOn(ColumnFamilyStore) - Method in class org.apache.cassandra.db.ReadExecutionController
-
- validTimestampTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- validWindowTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
-
- value() - Method in class org.apache.cassandra.cql3.ColumnCondition
-
- Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
-
- value() - Method in class org.apache.cassandra.cql3.Cql_Parser
-
- value() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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() - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- value() - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- value() - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- value - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
-
- value - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
-
- Value(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
-
- Value(ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.Tuples.Value
-
- Value(UserType, ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.UserTypes.Value
-
- value - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
-
- value - Variable in class org.apache.cassandra.db.LegacyLayout.LegacyCell
-
- value() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
-
- value() - Method in class org.apache.cassandra.db.rows.BufferCell
-
- value() - Method in class org.apache.cassandra.db.rows.Cell
-
The cell value.
- value() - Method in class org.apache.cassandra.db.rows.NativeCell
-
- value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
-
- value - Variable in class org.apache.cassandra.gms.VersionedValue
-
- value - Variable in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
-
- value - Variable in class org.apache.cassandra.index.sasi.plan.Expression.Bound
-
- value - Variable in class org.apache.cassandra.index.sasi.sa.Term
-
- value() - Method in class org.apache.cassandra.utils.DefaultValue
-
- value - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.ListType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.MapType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.SetType
-
- valueCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- valueFactory - Variable in class org.apache.cassandra.service.StorageService
-
- valueForToken(Token) - Method in class org.apache.cassandra.dht.Splitter
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
The length of values for this type if all values are of fixed length, -1 otherwise.
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.LongType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- valueOf(String) - Static method in enum org.apache.cassandra.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.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.ClusteringOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskOptimizationStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.MemtableAllocationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.StatementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.Conflicts.Resolution
-
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.LegacyLayout.LegacyCell.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.SerializationHelper.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.index.sasi.analyzer.StandardAnalyzer.TokenType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(Operator) - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
-
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.plan.Operation.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.AbstractIterator.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.transactions.IndexTransaction.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.compress.BufferType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SelectionReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SkippingReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.metrics.TableMetrics.Sampler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.net.ResourceLimits.Outcome
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.schema.CachingParams.Option
-
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.IndexMetadata.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.SpeculativeRetryParam.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.service.ActiveRepairService.Status
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.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.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Target
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.AsymmetricOrdering.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.ChecksumType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.MBeanWrapper.OnException
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.NativeLibrary.OSType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.Throwables.FileOpType
-
Returns the enum constant of this type with the specified name.
- valueRaw - Variable in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
-
- values() - Static method in enum org.apache.cassandra.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.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.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.config.ColumnDefinition.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.config.ColumnDefinition.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.CommitFailurePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.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.InternodeCompression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.MemtableAllocationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
-
- values - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
-
- values() - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
-
- values() - Static method in enum org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.Conflicts.Resolution
-
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.LegacyLayout.LegacyCell.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.SerializationHelper.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.rows.Unfiltered.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.transform.RTBoundValidator.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.WriteType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in enum org.apache.cassandra.exceptions.RequestFailureReason
-
- 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.index.sasi.analyzer.StandardAnalyzer.TokenType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.plan.Operation.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.utils.AbstractIterator.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.index.transactions.IndexTransaction.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.compress.BufferType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SelectionReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SkippingReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - 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.TableMetrics.Sampler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.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.repair.messages.RepairMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.repair.RepairParallelism
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - 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.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.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.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.SpeculativeRetryParam.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 - Variable in class org.apache.cassandra.serializers.MapSerializer
-
- values() - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.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.DataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Target
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.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.AsymmetricOrdering.Op
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- values() - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.ChecksumType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- values() - Static method in enum org.apache.cassandra.utils.MBeanWrapper.OnException
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.NativeLibrary.OSType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.Throwables.FileOpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valueSet() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- valuesOf(ColumnDefinition.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Sets
-
- VarcharAsBlobFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- VariableSpecifications - Class in org.apache.cassandra.cql3
-
- VariableSpecifications(List<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.VariableSpecifications
-
- verb - Variable in class org.apache.cassandra.net.MessageIn
-
- verb - Variable in class org.apache.cassandra.net.MessageOut
-
- verbose - Variable in class org.apache.cassandra.tools.LoaderOptions
-
- VERBOSE_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
- verbSerializers - Variable in class org.apache.cassandra.net.MessagingService
-
Messages we receive in IncomingTcpConnection have a Verb that tells us what kind of message it is.
- verbStages - Static variable in class org.apache.cassandra.net.MessagingService
-
- verbValues - Static variable in class org.apache.cassandra.net.MessagingService
-
- Verifier - Class in org.apache.cassandra.db.compaction
-
- Verifier(ColumnFamilyStore, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
-
- Verifier(ColumnFamilyStore, SSTableReader, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
-
- verify(String, byte[]) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
-
- verify(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- verify(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier
-
- verify() - Method in class org.apache.cassandra.service.StartupChecks
-
Run the configured tests and return a report detailing the results.
- verify(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- verify(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Verify (checksums of) the given keyspace.
- verify(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- verify(PrintStream, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Verify - Class in org.apache.cassandra.tools.nodetool
-
- Verify() - Constructor for class org.apache.cassandra.tools.nodetool.Verify
-
- verifyFullPermissions(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Checks whether Cassandra has RWX permissions to the specified directory.
- verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- version - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
-
- version - Variable in class org.apache.cassandra.db.rows.SerializationHelper
-
- version - Variable in class org.apache.cassandra.gms.VersionedValue
-
- version - Variable in class org.apache.cassandra.index.sasi.disk.Descriptor
-
- Version(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor.Version
-
- version - Variable in class org.apache.cassandra.index.sasi.disk.Descriptor.Version
-
- version - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
version has the following format: [a-z]+
- Version - Class in org.apache.cassandra.io.sstable.format
-
A set of feature flags associated with a SSTable format
versions are denoted as [major][minor].
- Version(SSTableFormat, String) - Constructor for class org.apache.cassandra.io.sstable.format.Version
-
- version - Variable in class org.apache.cassandra.io.sstable.format.Version
-
- version() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
-
- version - Variable in class org.apache.cassandra.net.MessageIn
-
- version - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable version
- Version - Class in org.apache.cassandra.tools.nodetool
-
- Version() - Constructor for class org.apache.cassandra.tools.nodetool.Version
-
- version - Variable in class org.apache.cassandra.transport.Frame.Header
-
- version - Variable in class org.apache.cassandra.transport.SimpleClient
-
- VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
Streaming protocol version
- VERSION_21 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_21 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_22 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_22 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_22 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- VERSION_30 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_30 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_30 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- VERSION_3014 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_AA - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
-
- VERSION_AB - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
-
- VersionAndType - Class in org.apache.cassandra.io.sstable.format
-
- VersionAndType(Version, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.format.VersionAndType
-
- VersionedValue - Class in org.apache.cassandra.gms
-
This abstraction represents the state associated with a particular node which an
application wants to make available to the rest of the nodes in the cluster.
- VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
-
- VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- VersionGenerator - Class in org.apache.cassandra.gms
-
A unique version number generator for any state that is generated by the
local node.
- VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
-
- versionsInUse() - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
-
The set of all sstable versions currently in use on this node.
- versionsInUse - Variable in class org.apache.cassandra.service.SSTablesVersionsInUseChangeNotification
-
The set of all sstable versions in use on this node at the time of this notification.
- View - 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(ViewDefinition, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.view.View
-
- View - Class in org.apache.cassandra.index.sasi.conf.view
-
- View(ColumnIndex, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
-
- View(ColumnIndex, Collection<SSTableIndex>, Collection<SSTableReader>, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
-
- VIEW_BUILD_STATUS - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- ViewBuilder - Class in org.apache.cassandra.db.view
-
- ViewBuilder(ColumnFamilyStore, View) - Constructor for class org.apache.cassandra.db.view.ViewBuilder
-
- ViewBuildStatus - Class in org.apache.cassandra.tools.nodetool
-
- ViewBuildStatus() - Constructor for class org.apache.cassandra.tools.nodetool.ViewBuildStatus
-
- ViewDefinition - Class in org.apache.cassandra.config
-
- ViewDefinition(ViewDefinition) - Constructor for class org.apache.cassandra.config.ViewDefinition
-
- ViewDefinition(String, String, UUID, String, boolean, SelectStatement.RawStatement, String, CFMetaData) - Constructor for class org.apache.cassandra.config.ViewDefinition
-
- ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- viewLockAcquireStart - Variable in class org.apache.cassandra.db.Mutation
-
- 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
-
- ViewManager(Keyspace) - Constructor for class org.apache.cassandra.db.view.ViewManager
-
- viewName - Variable in class org.apache.cassandra.config.ViewDefinition
-
- 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
-
- VIEWS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
- Views - Class in org.apache.cassandra.schema
-
- Views.Builder - Class in org.apache.cassandra.schema
-
- VIEWS_BUILDS_IN_PROGRESS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- viewStatus(String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- ViewUpdateGenerator - Class in org.apache.cassandra.db.view
-
Creates the updates to apply to a view given the existing rows in the base
table and the updates that we're applying to them (this handles updates
on a single partition only).
- ViewUpdateGenerator(View, DecoratedKey, int) - Constructor for class org.apache.cassandra.db.view.ViewUpdateGenerator
-
Creates a new ViewUpdateBuilder
.
- ViewUtils - Class in org.apache.cassandra.db.view
-
- viewWriteLatency - Variable in class org.apache.cassandra.metrics.ViewWriteMetrics
-
- ViewWriteMetrics - Class in org.apache.cassandra.metrics
-
- ViewWriteMetrics(String) - Constructor for class org.apache.cassandra.metrics.ViewWriteMetrics
-
- VIntCoding - Class in org.apache.cassandra.utils.vint
-
Borrows idea from
https://developers.google.com/protocol-buffers/docs/encoding#varints
- VIntCoding() - Constructor for class org.apache.cassandra.utils.vint.VIntCoding
-
- visible(SSTableReader, Predicate<SSTableReader>, Collection<SSTableReader>...) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
-
- visitDirectory(Path, Predicate<? super File>, Consumer<? super File>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- visitFile(Path, BasicFileAttributes) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
-
- visitFileFailed(Path, IOException) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
-
- vnodeCount - Variable in class org.apache.cassandra.service.StorageProxy.RangeForQuery
-
- vnodeCount() - Method in class org.apache.cassandra.service.StorageProxy.RangeForQuery
-
- Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
-