- A - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- A - Static variable in class org.apache.cassandra.cql.CqlParser
-
- a - Variable in class org.apache.cassandra.cql.Operation
-
- A - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- A - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- abort() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
After failure, attempt to close the index writer and data file before deleting all temp components for the sstable
- abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- AbstractBounds<T extends RingPosition> - Class in org.apache.cassandra.dht
-
- AbstractBounds(T, T, IPartitioner) - Constructor for class org.apache.cassandra.dht.AbstractBounds
-
- AbstractBounds.AbstractBoundsSerializer - Class in org.apache.cassandra.dht
-
- AbstractBounds.AbstractBoundsSerializer() - Constructor for class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- AbstractByteOrderedPartitioner - Class in org.apache.cassandra.dht
-
- AbstractByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- AbstractCassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
- AbstractCassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- AbstractCassandraStorage.MarshallerType - Enum in org.apache.cassandra.hadoop.pig
-
- AbstractColumnFamilyInputFormat<K,Y> - Class in org.apache.cassandra.hadoop
-
- AbstractColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- AbstractColumnFamilyOutputFormat<K,Y> - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
values) as Cassandra rows (and respective columns) in a given
ColumnFamily.
- AbstractColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
- AbstractColumnFamilyRecordWriter<K,Y> - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyRecordWriter
maps the output <key, value>
pairs to a Cassandra column family.
- AbstractColumnFamilyRecordWriter(Configuration) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- AbstractColumnFamilyRecordWriter.AbstractRangeClient<K> - Class in org.apache.cassandra.hadoop
-
A client that runs in a threadpool and connects to the list of endpoints for a particular
range.
- AbstractColumnFamilyRecordWriter.AbstractRangeClient(List<InetAddress>) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- AbstractCommitLogExecutorService - Class in org.apache.cassandra.db.commitlog
-
- AbstractCommitLogExecutorService() - Constructor for class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- AbstractCommutativeType - Class in org.apache.cassandra.db.marshal
-
- AbstractCommutativeType() - Constructor for class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- AbstractCompactedRow - Class in org.apache.cassandra.db.compaction
-
a CompactedRow is an object that takes a bunch of rows (keys + columnfamilies)
and can write a compacted version of those rows to an output stream.
- AbstractCompactedRow(DecoratedKey) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactedRow
-
- AbstractCompactionIterable - Class in org.apache.cassandra.db.compaction
-
- AbstractCompactionIterable(CompactionController, OperationType, List<ICompactionScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- AbstractCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
Pluggable compaction strategy determines how SSTables get merged.
- AbstractCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- AbstractCompactionTask - Class in org.apache.cassandra.db.compaction
-
- AbstractCompactionTask(ColumnFamilyStore, Iterable<SSTableReader>) - 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.CompositeComponent - Class in org.apache.cassandra.db.marshal
-
- AbstractCompositeType.CompositeComponent(AbstractType<?>, ByteBuffer) - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- AbstractCompositeType.ParsedComparator - Interface in org.apache.cassandra.db.marshal
-
- AbstractDataInput - Class in org.apache.cassandra.io.util
-
- AbstractDataInput() - Constructor for class org.apache.cassandra.io.util.AbstractDataInput
-
- AbstractDataOutput - Class in org.apache.cassandra.io.util
-
- AbstractDataOutput() - Constructor for class org.apache.cassandra.io.util.AbstractDataOutput
-
- AbstractEndpointSnitch - Class in org.apache.cassandra.locator
-
- AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- AbstractFunction - Class in org.apache.cassandra.cql3.functions
-
- AbstractFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
-
- AbstractJmxClient - Class in org.apache.cassandra.tools
-
- AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
-
- AbstractMarker - Class in org.apache.cassandra.cql3
-
A single bind marker.
- AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
-
- AbstractMarker.INRaw - Class in org.apache.cassandra.cql3
-
- AbstractMarker.INRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.INRaw
-
- AbstractMarker.Raw - Class in org.apache.cassandra.cql3
-
A parsed, but non prepared, bind marker.
- AbstractMarker.Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- AbstractModification - Class in org.apache.cassandra.cql
-
- AbstractModification(String, String, String, Attributes) - Constructor for class org.apache.cassandra.cql.AbstractModification
-
- AbstractModification(String, String, String, ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.AbstractModification
-
- 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
-
- AbstractPartitioner<T extends Token> - Class in org.apache.cassandra.dht
-
- AbstractPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractPartitioner
-
- AbstractPaxosCallback<T> - Class in org.apache.cassandra.service.paxos
-
- AbstractPaxosCallback(int) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- AbstractRangeCommand - Class in org.apache.cassandra.db
-
- AbstractRangeCommand(String, String, long, AbstractBounds<RowPosition>, IDiskAtomFilter, List<IndexExpression>) - Constructor for class org.apache.cassandra.db.AbstractRangeCommand
-
- AbstractReadExecutor - Class in org.apache.cassandra.service
-
- AbstractReplicationStrategy - Class in org.apache.cassandra.locator
-
A abstract parent for all replication strategies.
- AbstractRowResolver - Class in org.apache.cassandra.service
-
- AbstractRowResolver(ByteBuffer, String) - Constructor for class org.apache.cassandra.service.AbstractRowResolver
-
- AbstractSimplePerColumnSecondaryIndex - Class in org.apache.cassandra.db.index
-
Implements a secondary index for a column family using a second column family
in which the row keys are indexed values, and column names are base row keys.
- AbstractSimplePerColumnSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- AbstractSSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
-
- AbstractSSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- AbstractTextSerializer - Class in org.apache.cassandra.serializers
-
- AbstractTextSerializer(Charset) - Constructor for class org.apache.cassandra.serializers.AbstractTextSerializer
-
- AbstractThreadUnsafeSortedColumns - Class in org.apache.cassandra.db
-
- AbstractThreadUnsafeSortedColumns(CFMetaData) - Constructor for class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- AbstractThreadUnsafeSortedColumns(CFMetaData, DeletionInfo) - Constructor for class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- AbstractType<T> - Class in org.apache.cassandra.db.marshal
-
Specifies a Comparator for a specific type of ByteBuffer.
- AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
-
- AbstractWriteResponseHandler - Class in org.apache.cassandra.service
-
- AbstractWriteResponseHandler(Keyspace, Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
-
- acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- ackCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- ackCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- acquireReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- acquireReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- activate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to initialize and start the daemon in one shot.
- ActiveRepairService - Class in org.apache.cassandra.service
-
ActiveRepairService is the starting point for manual "active" repairs.
- ActiveRepairService() - Constructor for class org.apache.cassandra.service.ActiveRepairService
-
Protected constructor.
- ActiveRepairService.Status - Enum in org.apache.cassandra.service
-
- activeSegment - Variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- activeSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Used by tests.
- activeStreamsOutbound - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of active tasks.
- adaptor - Variable in class org.apache.cassandra.cli.CliParser
-
- add(ByteBuffer) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Add a new ByteBuffer as the next component for this name.
- add(ByteBuffer, Relation.Type) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Add a new ByteBuffer as the next component for this name.
- add(Column) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- add(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
-
- add(Column) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
-
- add(int, ColumnSpecification) - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- add(OnDiskAtom) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
-
- add(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Add a RowMutation to the commit log.
- add(CommitLog.LogRecordAdder) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
submits the adder for execution and blocks for it to be synced, if necessary
- add(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- add(DeletionTime) - Method in class org.apache.cassandra.db.DeletionInfo
-
- add(RangeTombstone, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.DeletionInfo
-
- add(DeletionInfo) - Method in class org.apache.cassandra.db.DeletionInfo
-
Adds the provided deletion infos to the current ones.
- add(ByteBuffer, Relation.Type) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- add(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- add(ByteBuffer, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Adds a new range tombstone.
- add(ColumnFamily) - Method in class org.apache.cassandra.db.RowMutation
-
- add(String, ByteBuffer, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RowMutation
-
- add(String, ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
-
- add(IMessageSink) - Static method in class org.apache.cassandra.net.sink.SinkManager
-
- add(R) - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- add(AbstractCompactedRow) - Method in class org.apache.cassandra.repair.Validator
-
Called (in order) for every row present in the CF.
- add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- add(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- add(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
-
- add(double) - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Increments the count of the bucket closest to n, rounding UP.
- add(long) - Method in class org.apache.cassandra.utils.HistogramBuilder
-
- add(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
-
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.ColumnFamily
-
Adds all the columns of a given column map to this column map.
- addAll(ColumnFamily, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addAll(IMutation) - Method in class org.apache.cassandra.db.CounterMutation
-
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.EmptyColumns
-
- addAll(IMutation) - Method in interface org.apache.cassandra.db.IMutation
-
- addAll(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Adds all the range tombstones of tombstones
to this RangeTombstoneList.
- addAll(IMutation) - Method in class org.apache.cassandra.db.RowMutation
-
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
We need to go through each column in the column container and resolve it before adding
- addAll(ColumnFamily, Allocator, Function<Column, Column>) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- addAllWithSizeDelta(ColumnFamily, Allocator, Function<Column, Column>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
This is only called by Memtable.resolve, so only AtomicSortedColumns needs to implement it.
- addAncestor(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- addAtom(OnDiskAtom) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- addBootstrapTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- addCallback(IAsyncCallback, MessageOut, InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
-
- addClassPath(File) - Method in class org.apache.cassandra.triggers.CustomClassLoader
-
- addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
-
- addColumn(Term, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Map a column name to a validator for its value
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
AddColumn throws an exception if the column added does not sort after
the last column in the map.
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- addColumn(Column) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addColumn(ByteBuffer, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
-
Adds a column to this column map.
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.EmptyColumns
-
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- addColumn(Column, Allocator) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- addColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
Insert a new "regular" column to the current row (and super column if applicable).
- addColumn(ColumnFamily, ByteBuffer, InetAddress) - Static method in class org.apache.cassandra.tracing.Tracing
-
- addColumn(ColumnFamily, ByteBuffer, int) - Static method in class org.apache.cassandra.tracing.Tracing
-
- addColumn(ColumnFamily, ByteBuffer, long) - Static method in class org.apache.cassandra.tracing.Tracing
-
- addColumn(ColumnFamily, ByteBuffer, String) - Static method in class org.apache.cassandra.tracing.Tracing
-
- addColumnAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- addColumnCount(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- addColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- addColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- addColumnMetadataFromAliases(List<ByteBuffer>, AbstractType<?>, ColumnDefinition.Type) - Method in class org.apache.cassandra.config.CFMetaData
-
- addColumnValue(ByteBuffer) - Method in class org.apache.cassandra.cql3.ResultSet
-
- addComponents(Collection<Component>) - Method in class org.apache.cassandra.io.sstable.SSTable
-
Registers new custom components.
- addCompressionRatio(long, long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
Ratio is compressed/uncompressed and it is
if you have 1.x then compression isn't helping
- addCondition(Operation) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addConnection(Channel, Connection) - Method in interface org.apache.cassandra.transport.Connection.Tracker
-
- addConnection(Channel, Connection) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- addCounter(ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addCounter(String, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
-
- addCounterColumn(ByteBuffer, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
Insert a new counter column to the current row (and super column if applicable).
- addDefaultIndexNames() - Method in class org.apache.cassandra.config.CFMetaData
-
Convert a null index_name to appropriate default name according to column status
- addDefinition(ColumnIdentifier, CQL3Type) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
-
- added - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- addEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
Stores current DC/rack assignment for ep
- addEventListener(StreamEventHandler) - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- addExpireTimeForEndpoint(InetAddress, long) - Method in class org.apache.cassandra.gms.Gossiper
-
- addExpireTimeIfFound(InetAddress, long) - Method in class org.apache.cassandra.service.StorageService
-
- addExpiringColumn(ByteBuffer, ByteBuffer, long, int, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
Insert a new expiring column to the current row (and super column if applicable).
- addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- addIfRelevant(Column, DeletionInfo.InOrderTester, int) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addIndexedColumn(ColumnDefinition) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Adds and builds a index for a column
- addInitialSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- addInValue(Term.Raw) - Method in class org.apache.cassandra.cql3.Relation
-
- addKeyAliases(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- addKeyspace() - Method in class org.apache.cassandra.cli.CliParser
-
- addKeyValue(ColumnIdentifier, Term) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addLatency(InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
-
- addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- addMicro(long) - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
- addMicro(long) - Method in class org.apache.cassandra.utils.LatencyTracker
-
- 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
- addNano(long) - Method in class org.apache.cassandra.utils.LatencyTracker
-
takes nanoseconds
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- addOperation(Operation) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- addOption(String, String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option with argument and argument name
- addOption(String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option without argument
- addOrGet(String) - Method in class org.apache.cassandra.db.RowMutation
-
- addOrGet(CFMetaData) - Method in class org.apache.cassandra.db.RowMutation
-
- addOrReplaceColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- addParameterColumns(ColumnFamily, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
-
- addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
-
- addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
-
- addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
Adds a position that would be a safe place for a segment boundary in the file.
- addProperty(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
Map a keyword to the corresponding value
- addProperty(String, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Map a keyword to the corresponding value
- addProperty(String, String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- addProperty(String, Map<String, String>) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- addr - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- addRangeForEndpoint(Range<Token>, InetAddress) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- addRanges(String, Collection<Range<Token>>) - Method in class org.apache.cassandra.dht.RangeStreamer
-
- addRawUpdate(List<Pair<ColumnIdentifier, Operation.RawUpdate>>, ColumnIdentifier, Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.CqlParser
-
- addRecognitionError(String) - Method in class org.apache.cassandra.cql3.CqlParser
-
- addRelocatingTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Add new relocating ranges (tokens moving from their respective endpoints, to another).
- address - Variable in class org.apache.cassandra.dht.BootStrapper
-
- address - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
- address - Variable in class org.apache.cassandra.thrift.ThriftServer
-
- addRow(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.ResultSet
-
- addRowSize(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Add an endpoint we knew about previously, but whose state is unknown
- addSeed(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSeedProvider
-
- addSourceFilter(RangeStreamer.ISourceFilter) - Method in class org.apache.cassandra.dht.RangeStreamer
-
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- addStreamRequest(String, Collection<Range<Token>>, Collection<String>) - Method in class org.apache.cassandra.streaming.StreamSession
-
Request data fetch task to this session.
- addToActiveSessions(RepairSession) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- addTombstone(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addTombstone(ByteBuffer, int, long) - Method in class org.apache.cassandra.db.ColumnFamily
-
- addToTotalBytesCompacted(long) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- addToVersion(int) - Method in enum org.apache.cassandra.transport.Message.Direction
-
- addTransferFile(SSTableReader, long, List<Pair<Long, Long>>) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- addTransferFiles(Collection<Range<Token>>, Collection<SSTableReader>) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set up transfer of the specific SSTables.
- addTransferFiles(Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamSession
-
- addTransferRanges(String, Collection<Range<Token>>, Collection<String>, boolean) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set up transfer for specific keyspace/ranges/CFs
- addTree(InetAddress, MerkleTree) - Method in class org.apache.cassandra.repair.RepairJob
-
Add a new received tree and return the number of remaining tree to
be received for the job to be complete.
- addTriggerDefinition(TriggerDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- 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 'removetoken' invoked
- advertiseTokenRemoved(InetAddress, UUID) - Method in class org.apache.cassandra.gms.Gossiper
-
Handles switching the endpoint's state from REMOVING_TOKEN to REMOVED_TOKEN
This should only be called after advertiseRemoving
- affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
-
- affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
-
- affectedColumn() - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
-
The name of the column affected by this delete operation.
- afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- alias - Variable in class org.apache.cassandra.cql3.statements.RawSelector
-
- alive - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- ALL - Static variable in enum org.apache.cassandra.auth.Permission
-
- all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- all() - Static method in class org.apache.cassandra.db.Keyspace
-
- ALL_COLUMNS - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- ALL_COLUMNS_ARRAY - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- ALL_DATA - Static variable in enum org.apache.cassandra.auth.Permission
-
- allChannels - Variable in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- allColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- allData(IPartitioner) - Static method in class org.apache.cassandra.db.DataRange
-
- allIndexesNames() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- allocate(int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- allocate(int, int, Allocator) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- allocate(long) - Method in interface org.apache.cassandra.io.util.IAllocator
-
- allocate(long) - Method in class org.apache.cassandra.io.util.JEMallocAllocator
-
- allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
-
- allocate(long) - Method in class org.apache.cassandra.io.util.NativeAllocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.Allocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.HeapAllocator
-
- allocate(int) - Method in class org.apache.cassandra.utils.SlabAllocator
-
- allocator - Variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- Allocator - Class in org.apache.cassandra.utils
-
- Allocator() - Constructor for class org.apache.cassandra.utils.Allocator
-
- AllowAllAuthenticator - Class in org.apache.cassandra.auth
-
- AllowAllAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllAuthenticator
-
- AllowAllAuthorizer - Class in org.apache.cassandra.auth
-
- AllowAllAuthorizer() - Constructor for class org.apache.cassandra.auth.AllowAllAuthorizer
-
- AllowAllInternodeAuthenticator - Class in org.apache.cassandra.auth
-
- AllowAllInternodeAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- allowedKeywords - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- Alnum - Static variable in class org.apache.cassandra.cli.CliLexer
-
- Alnum - Static variable in class org.apache.cassandra.cli.CliParser
-
- AlreadyExistsException - Exception in org.apache.cassandra.exceptions
-
- AlreadyExistsException(String, String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- AlreadyExistsException(String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of ALTER USER query.
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- alterableOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- alterableOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Subset of supportedOptions that users are allowed to alter when performing ALTER USER [themselves].
- alterableOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- alterableOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- alterKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterKeyspaceStatement(String, KSPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- AlterTableStatement - Class in org.apache.cassandra.cql
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String, String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- alterTableStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- alterTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterTableStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterTableStatement(CFName, AlterTableStatement.Type, ColumnIdentifier, CQL3Type, CFPropDefs, Map<ColumnIdentifier, ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- AlterTableStatement.OperationType - Enum in org.apache.cassandra.cql
-
- AlterTableStatement.Type - Enum in org.apache.cassandra.cql3.statements
-
- alterUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterUserStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterUserStatement(String, UserOptions, Boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- AlwaysPresent - Static variable in class org.apache.cassandra.utils.FilterFactory
-
- AlwaysPresentFilter - Class in org.apache.cassandra.utils
-
- AlwaysPresentFilter() - Constructor for class org.apache.cassandra.utils.AlwaysPresentFilter
-
- ancestors - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- AND - Static variable in class org.apache.cassandra.cli.CliLexer
-
- AND - Static variable in class org.apache.cassandra.cli.CliParser
-
- and(Term) - Method in class org.apache.cassandra.cql.SelectExpression
-
Add an additional column name to a SelectExpression.
- and(Relation) - Method in class org.apache.cassandra.cql.WhereClause
-
Add an additional relation to this WHERE clause.
- and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- andKeyEquals(Term) - Method in class org.apache.cassandra.cql.WhereClause
-
The same as KEY = to avoid using Relation object
- announceColumnFamilyDrop(String, String) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceDrop(String) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceKeyspaceUpdate(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- announceMigration() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- announceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewKeyspace(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewKeyspace(KSMetaData, long) - 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
-
- API_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
-
- API_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
-
- append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- append(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- appendFromStream(DecoratedKey, CFMetaData, DataInput, Descriptor.Version) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Appends new component names to the TOC component.
- appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.ListType
-
- appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.MapType
-
- appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.SetType
-
- ApplicationState - Enum in org.apache.cassandra.gms
-
- apply(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
Updates CFMetaData in-place to match cf_def
*Note*: This method left public only for DefsTest, don't use directly!
- apply(ColumnDefinition, AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- apply(DecoratedKey, ColumnFamily, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Insert/Update the column family for this key.
- apply() - Method in class org.apache.cassandra.db.CounterMutation
-
- apply() - Method in interface org.apache.cassandra.db.IMutation
-
- apply(RowMutation, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
- apply(RowMutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
This method appends a row to the global CommitLog, then updates memtables and indexes.
- apply() - Method in class org.apache.cassandra.db.RowMutation
-
- apply(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- apply(IMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, String, ConsistencyLevel) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
-
- applyCounterMutationOnCoordinator(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
-
- applyCounterMutationOnLeader(CounterMutation, String, Runnable) - Static method in class org.apache.cassandra.service.StorageProxy
-
- applyImplicitDefaults(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
-
applies implicit defaults to cf definition.
- applyPropertiesTo(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- applyPropertiesToCFMetadata(CFMetaData, CFPropDefs) - Static method in class org.apache.cassandra.cql.AlterTableStatement
-
- applyStateTransition(Message.Type, Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
-
- applyToCFMetadata(CFMetaData) - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- applyUnsafe() - Method in class org.apache.cassandra.db.RowMutation
-
- archivePending - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- archiver - Variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- args - Variable in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- argsType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argsType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argsType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- ARRAY - Static variable in class org.apache.cassandra.cli.CliLexer
-
- ARRAY - Static variable in class org.apache.cassandra.cli.CliParser
-
- ArrayBackedSortedColumns - Class in org.apache.cassandra.db
-
A ColumnFamily backed by an ArrayList.
- arrayConstruct() - Method in class org.apache.cassandra.cli.CliParser
-
- 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.
- AsciiSerializer - Class in org.apache.cassandra.serializers
-
- AsciiType - Class in org.apache.cassandra.db.marshal
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DateType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.LongType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- asIFilter(SlicePredicate, CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- asKSMetadata(String) - Method in class org.apache.cassandra.cql3.KSPropDefs
-
- asKSMetadataUpdate(KSMetaData) - Method in class org.apache.cassandra.cql3.KSPropDefs
-
- asList() - Method in class org.apache.cassandra.dht.Range
-
- asMap() - Method in class org.apache.cassandra.db.ColumnFamily
-
- asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- AssignementTestable - Interface in org.apache.cassandra.cql3
-
- ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
-
- ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
-
- assumeStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- assureSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.ReadCallback
-
- asTemporary(boolean) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- asThriftOptions() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- ASYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer
-
- AsyncOneResponse<T> - Class in org.apache.cassandra.net
-
A callback specialized for returning a value from a single target; that is, this is for messages
that we only send to one recipient.
- AsyncOneResponse() - Constructor for class org.apache.cassandra.net.AsyncOneResponse
-
- AsyncRepairCallback - Class in org.apache.cassandra.service
-
- AsyncRepairCallback(RowDataResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
-
- atomic_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- AtomicSortedColumns - Class in org.apache.cassandra.db
-
A thread-safe and atomic ISortedColumns implementation.
- attach(Connection) - Method in class org.apache.cassandra.transport.Message
-
- attachSocket(InetAddress, Socket, boolean, int) - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- attr_name() - Method in class org.apache.cassandra.cli.CliParser
-
- Attributes - Class in org.apache.cassandra.cql
-
Class to contain attributes for statements
- Attributes() - Constructor for class org.apache.cassandra.cql.Attributes
-
- Attributes(ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.Attributes
-
- Attributes - Class in org.apache.cassandra.cql3
-
Utility class for the Parser to gather attributes for modification
statements.
- Attributes.Raw - Class in org.apache.cassandra.cql3
-
- Attributes.Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
-
- attrs - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- attrValue() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueDouble() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueInt() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueString() - Method in class org.apache.cassandra.cli.CliParser
-
- augment(ByteBuffer, ColumnFamily) - Method in interface org.apache.cassandra.triggers.ITrigger
-
Called exactly once per CF update, returned mutations are atomically updated.
- Auth - Class in org.apache.cassandra.auth
-
- Auth() - Constructor for class org.apache.cassandra.auth.Auth
-
- Auth.MigrationListener - Class in org.apache.cassandra.auth
-
IMigrationListener implementation that cleans up permissions on dropped resources.
- Auth.MigrationListener() - Constructor for class org.apache.cassandra.auth.Auth.MigrationListener
-
- AUTH_KS - Static variable in class org.apache.cassandra.auth.Auth
-
- AuthChallenge - Class in org.apache.cassandra.transport.messages
-
SASL challenge sent from client to server
- AuthChallenge(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthChallenge
-
- authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- authenticate(Map<String, String>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Authenticates a user given a Map of credentials.
- authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Decides whether or not a peer is allowed to connect to this node.
- authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- AuthenticatedUser - Class in org.apache.cassandra.auth
-
Returned from IAuthenticator#authenticate(), represents an authenticated user everywhere internally.
- AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
-
- AuthenticateMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- AuthenticateMessage(String) - Constructor for class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthenticationException - Exception in org.apache.cassandra.exceptions
-
- AuthenticationException(String) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
-
- AuthenticationStatement - Class in org.apache.cassandra.cql3.statements
-
- AuthenticationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- authenticator - Variable in class org.apache.cassandra.config.Config
-
- authenticator - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthorizationStatement - Class in org.apache.cassandra.cql3.statements
-
- AuthorizationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
The primary IAuthorizer method.
- authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
Translates new-style authorize() method call to the old-style (including permissions and the hierarchy).
- authorizer - Variable in class org.apache.cassandra.config.Config
-
- AuthResponse - Class in org.apache.cassandra.transport.messages
-
A SASL token message sent from client to server.
- AuthResponse(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthResponse
-
- AuthSuccess - Class in org.apache.cassandra.transport.messages
-
Indicates to the client that authentication has succeeded.
- AuthSuccess(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthSuccess
-
- auto_bootstrap - Variable in class org.apache.cassandra.config.Config
-
- auto_snapshot - Variable in class org.apache.cassandra.config.Config
-
- AutoSavingCache<K extends CacheKey,V> - Class in org.apache.cassandra.cache
-
- AutoSavingCache(ICache<K, V>, CacheService.CacheType, AutoSavingCache.CacheSerializer<K, V>) - Constructor for class org.apache.cassandra.cache.AutoSavingCache
-
- AutoSavingCache.CacheSerializer<K extends CacheKey,V> - Interface in org.apache.cassandra.cache
-
- AutoSavingCache.Writer - Class in org.apache.cassandra.cache
-
- AutoSavingCache.Writer(int) - Constructor for class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- available() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Returns the number of bytes that are available before this stream will
block.
- available() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- aVeryLongTime - Static variable in class org.apache.cassandra.gms.Gossiper
-
- await() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- await(long, TimeUnit) - Method in class org.apache.cassandra.service.ReadCallback
-
- await() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- await(long, TimeUnit) - Method in class org.apache.cassandra.utils.SimpleCondition
-
- awaitNanos(long) - Method in class org.apache.cassandra.utils.SimpleCondition
-
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- awaitTermination() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Returns when the allocator thread terminates.
- awaitTermination() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
Blocks until shutdown is complete.
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- awaitUntil(Date) - Method in class org.apache.cassandra.utils.SimpleCondition
-
- C - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- C - Static variable in class org.apache.cassandra.cql.CqlParser
-
- C - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- C - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- CACHE_FLUSH_INTERVAL_IN_BYTES - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- cacheEndpoint(Token, ArrayList<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- cacheForPathCreator - Variable in class org.apache.cassandra.service.FileCacheService
-
- CacheKey - Interface in org.apache.cassandra.cache
-
- cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- CacheMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ICache
.
- CacheMetrics(String, ICache) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
-
Create metrics for given cache.
- CacheService - Class in org.apache.cassandra.service
-
- CacheService.CacheType - Enum in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- CacheServiceMBean - Interface in org.apache.cassandra.service
-
- cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- caching(CFMetaData.Caching) - Method in class org.apache.cassandra.config.CFMetaData
-
- calculateHintTTL(RowMutation) - Static method in class org.apache.cassandra.db.HintedHandOffManager
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the natural endpoints for the given token
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
calculate endpoints in one pass through the tokens by tracking our progress in each DC, rack etc.
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.StorageService
-
- calculateRelocations(Multimap<String, String>) - Method in class org.apache.cassandra.tools.Shuffle
-
Given a Multimap of endpoint to tokens, return a new randomized mapping.
- calculateStreamAndFetchRanges(Collection<Range<Token>>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.StorageService
-
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
- callback - Variable in class org.apache.cassandra.net.CallbackInfo
-
- callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- callbackDeserializers - Static variable in class org.apache.cassandra.net.MessagingService
-
A Map of what kind of serializer to wire up to a REQUEST_RESPONSE callback, based on outbound Verb.
- CallbackInfo - Class in org.apache.cassandra.net
-
Encapsulates the callback information.
- CallbackInfo(InetAddress, IAsyncCallback, IVersionedSerializer<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
Create CallbackInfo without sent message
- CallbackInfo(InetAddress, IAsyncCallback, MessageOut<?>, IVersionedSerializer<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
- canHaveOnlyOneValue() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- capacity() - Method in interface org.apache.cassandra.cache.ICache
-
- capacity() - Method in class org.apache.cassandra.cache.SerializingCache
-
- capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Cache capacity in bytes
- capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity in bits (1 greater than the index of the last bit)
- cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- cas(String, String, ByteBuffer, ColumnNameBuilder, ColumnFamily, ColumnFamily, ConsistencyLevel, ConsistencyLevel) - 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 ones given by @param expected.
- 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
-
- CASSANDRA_HADOOP_MAX_KEY_SIZE - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- CassandraAuthorizer - Class in org.apache.cassandra.auth
-
CassandraAuthorizer is an IAuthorizer implementation that keeps
permissions internally in C* - in system_auth.permissions CQL3 table.
- CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
-
- CassandraDaemon - Class in org.apache.cassandra.service
-
- CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon.Server - Interface in org.apache.cassandra.service
-
- CassandraException - Exception in org.apache.cassandra.exceptions
-
- CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraServer - Class in org.apache.cassandra.thrift
-
- CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
-
- cassandraServer - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- CassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
A row from a standard CF will be returned as nested tuples: (key, ((name1, val1), (name2, val2))).
- CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- CBCodec<T> - Interface in org.apache.cassandra.transport
-
- CBUtil - Class in org.apache.cassandra.transport
-
ChannelBuffer utility methods.
- cellName - Variable in class org.apache.cassandra.service.pager.PagingState
-
- cf - Variable in class org.apache.cassandra.db.Row
-
- cfamColumns(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamDefinition(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamOrdering(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfamProperty(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- cfDef - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert string back to CfDef
- CFDefinition - Class in org.apache.cassandra.cql3
-
Holds metadata on a CF preprocessed for use by CQL queries.
- CFDefinition(CFMetaData) - Constructor for class org.apache.cassandra.cql3.CFDefinition
-
- CFDefinition.Name - Class in org.apache.cassandra.cql3
-
- CFDefinition.Name.Kind - Enum in org.apache.cassandra.cql3
-
- cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert CfDef to string
- cfId - Variable in class org.apache.cassandra.cache.RowCacheKey
-
- cfId - Variable in class org.apache.cassandra.config.CFMetaData
-
- cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamReader
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamTask
-
- cfIdSerializedSize(UUID, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- cfm - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- cfm - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- CFMetaData - Class in org.apache.cassandra.config
-
- CFMetaData(String, String, ColumnFamilyType, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.config.CFMetaData
-
- CFMetaData(String, String, ColumnFamilyType, AbstractType<?>) - Constructor for class org.apache.cassandra.config.CFMetaData
-
- cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
-
- CFMetaData.Caching - Enum in org.apache.cassandra.config
-
- CFMetaData.SpeculativeRetry - Class in org.apache.cassandra.config
-
- CFMetaData.SpeculativeRetry.RetryType - Enum in org.apache.cassandra.config
-
- cfName - Variable in class org.apache.cassandra.config.CFMetaData
-
- CFName - Class in org.apache.cassandra.cql3
-
- CFName() - Constructor for class org.apache.cassandra.cql3.CFName
-
- cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
-
- cfName - Variable in class org.apache.cassandra.db.filter.QueryFilter
-
- cfName - Variable in class org.apache.cassandra.db.ReadCommand
-
- cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- cfOrKsName(CFName, boolean) - Method in class org.apache.cassandra.cql3.CqlParser
-
- CFPropDefs - Class in org.apache.cassandra.cql
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql.CFPropDefs
-
- CFPropDefs - Class in org.apache.cassandra.cql3
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql3.CFPropDefs
-
- 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.Scrubber
-
- cfs - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
-
- cfs - Variable in class org.apache.cassandra.db.Memtable
-
- cfs - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- 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
-
- cfstore - Variable in class org.apache.cassandra.db.DataTracker
-
- cfType - Variable in class org.apache.cassandra.config.CFMetaData
-
- chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
-
Construct a chain of resource parents starting with the resource and ending with the root.
- change - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- change - Variable in class org.apache.cassandra.transport.Event.TopologyChange
-
- change - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- channel() - Method in class org.apache.cassandra.transport.Connection
-
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
-
- CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
-
- checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform any access verification necessary for the statement.
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- checkHealth() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
One of three things will happen if you try to read the system keyspace:
1.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- checkSeedContact(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- ChecksummedOutputStream - Class in org.apache.cassandra.io.util
-
- ChecksummedOutputStream(OutputStream, Checksum) - Constructor for class org.apache.cassandra.io.util.ChecksummedOutputStream
-
- checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- checksumWriter(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- chunkFor(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Get a chunk of compressed data (offset, length) corresponding to given position
- chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- chunkOffsetBy(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Get a chunk offset by it's index.
- chunks - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- cident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- class_name - Variable in class org.apache.cassandra.config.SeedProviderDef
-
- classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- classOption - Variable in class org.apache.cassandra.config.TriggerDefinition
-
- clean(MappedByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cleanup() - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
Do whatever action is needed to reclaim ressources used by this SegmentedFile.
- cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- clear() - Method in interface org.apache.cassandra.cache.ICache
-
- clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- clear() - Method in class org.apache.cassandra.cache.SerializingCache
-
- clear() - Method in class org.apache.cassandra.config.Schema
-
Clear all KS/CF metadata and reset version.
- clear() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clear this column family, removing all columns and deletion info.
- clear() - Method in class org.apache.cassandra.db.EmptyColumns
-
- 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.TreeMapBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- clear(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- clear(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Clear any existing interval timings for this endpoint
- clear() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- clear() - Static method in class org.apache.cassandra.net.sink.SinkManager
-
- clear() - Method in class org.apache.cassandra.tools.Shuffle
-
Clear pending token relocations on all nodes.
- 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.BoundedStatsDeque
-
- 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
-
- clearAllDelta(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Remove all the delta of a context (i.e, set an empty header).
- clearCallbacksUnsafe() - Method in class org.apache.cassandra.net.MessagingService
-
- clearEndpointCache() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- clearKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace definition from system
- clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- clearSnapshot(String) - Method in class org.apache.cassandra.db.Directories
-
- clearSnapshot(String) - 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.
- clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
For testing.
- clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
-
used by tests
- cLevel - Variable in class org.apache.cassandra.cql.AbstractModification
-
- CLibrary - Class in org.apache.cassandra.utils
-
- CliClient - Class in org.apache.cassandra.cli
-
- CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
-
- CliClient.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
-
- CliClient.Function - Enum in org.apache.cassandra.cli
-
Available value conversion functions
Used by convertValueByFunction(Tree functionCall) method
- CliCommandHelp - Class in org.apache.cassandra.cli
-
- CliCommandHelp() - Constructor for class org.apache.cassandra.cli.CliCommandHelp
-
- CliCompiler - Class in org.apache.cassandra.cli
-
- CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
-
- CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
-
- CliCompiler.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
-
- CliCompleter - Class in org.apache.cassandra.cli
-
- CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
-
- client - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- Client - Class in org.apache.cassandra.transport
-
- Client(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
-
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- 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() - Constructor for class org.apache.cassandra.service.ClientState
-
- ClientState(boolean) - Constructor for class org.apache.cassandra.service.ClientState
-
Construct a new, empty ClientState
- CliLexer - Class in org.apache.cassandra.cli
-
- CliLexer() - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliLexer(CharStream) - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliMain - Class in org.apache.cassandra.cli
-
Cassandra Command Line Interface (CLI) Main
- CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
-
- CliOptions - Class in org.apache.cassandra.cli
-
Used to process, and act upon the arguments passed to the CLI.
- CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
-
- CliParser - Class in org.apache.cassandra.cli
-
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
- CliParser(TokenStream) - Constructor for class org.apache.cassandra.cli.CliParser
-
- CliParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliParser
-
- CliParser.addColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.addColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.addColumnFamily_return
-
- CliParser.addKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.addKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.addKeyspace_return
-
- CliParser.arrayConstruct_return - Class in org.apache.cassandra.cli
-
- CliParser.arrayConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.arrayConstruct_return
-
- CliParser.assumeStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.assumeStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.assumeStatement_return
-
- CliParser.attr_name_return - Class in org.apache.cassandra.cli
-
- CliParser.attr_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.attr_name_return
-
- CliParser.attrValue_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValue_return
-
- CliParser.attrValueDouble_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueDouble_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueDouble_return
-
- CliParser.attrValueInt_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueInt_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueInt_return
-
- CliParser.attrValueString_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueString_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueString_return
-
- CliParser.columnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.columnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamily_return
-
- CliParser.columnFamilyExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.columnFamilyExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
-
- CliParser.columnLimitExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.columnLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
-
- CliParser.columnName_return - Class in org.apache.cassandra.cli
-
- CliParser.columnName_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnName_return
-
- CliParser.columnOrSuperColumn_return - Class in org.apache.cassandra.cli
-
- CliParser.columnOrSuperColumn_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
-
- CliParser.command_return - Class in org.apache.cassandra.cli
-
- CliParser.command_return() - Constructor for class org.apache.cassandra.cli.CliParser.command_return
-
- CliParser.comparator_return - Class in org.apache.cassandra.cli
-
- CliParser.comparator_return() - Constructor for class org.apache.cassandra.cli.CliParser.comparator_return
-
- CliParser.connectStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.connectStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.connectStatement_return
-
- CliParser.consistencyLevelStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.consistencyLevelStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
-
- CliParser.countStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.countStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.countStatement_return
-
- CliParser.delColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.delColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.delColumnFamily_return
-
- CliParser.delKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.delKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.delKeyspace_return
-
- CliParser.delStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.delStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.delStatement_return
-
- CliParser.describeCluster_return - Class in org.apache.cassandra.cli
-
- CliParser.describeCluster_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeCluster_return
-
- CliParser.describeTable_return - Class in org.apache.cassandra.cli
-
- CliParser.describeTable_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeTable_return
-
- CliParser.dropIndex_return - Class in org.apache.cassandra.cli
-
- CliParser.dropIndex_return() - Constructor for class org.apache.cassandra.cli.CliParser.dropIndex_return
-
- CliParser.entityName_return - Class in org.apache.cassandra.cli
-
- CliParser.entityName_return() - Constructor for class org.apache.cassandra.cli.CliParser.entityName_return
-
- CliParser.exitStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.exitStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.exitStatement_return
-
- CliParser.functionArgument_return - Class in org.apache.cassandra.cli
-
- CliParser.functionArgument_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionArgument_return
-
- CliParser.functionCall_return - Class in org.apache.cassandra.cli
-
- CliParser.functionCall_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionCall_return
-
- CliParser.getCondition_return - Class in org.apache.cassandra.cli
-
- CliParser.getCondition_return() - Constructor for class org.apache.cassandra.cli.CliParser.getCondition_return
-
- CliParser.getStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.getStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.getStatement_return
-
- CliParser.hashConstruct_return - Class in org.apache.cassandra.cli
-
- CliParser.hashConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashConstruct_return
-
- CliParser.hashElementPair_return - Class in org.apache.cassandra.cli
-
- CliParser.hashElementPair_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashElementPair_return
-
- CliParser.helpStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.helpStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.helpStatement_return
-
- CliParser.host_name_return - Class in org.apache.cassandra.cli
-
- CliParser.host_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_name_return
-
- CliParser.host_return - Class in org.apache.cassandra.cli
-
- CliParser.host_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_return
-
- CliParser.incrementValue_return - Class in org.apache.cassandra.cli
-
- CliParser.incrementValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrementValue_return
-
- CliParser.incrStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.incrStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrStatement_return
-
- CliParser.ip_address_return - Class in org.apache.cassandra.cli
-
- CliParser.ip_address_return() - Constructor for class org.apache.cassandra.cli.CliParser.ip_address_return
-
- CliParser.keyRangeExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.keyRangeExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
-
- CliParser.keyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.keyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspace_return
-
- CliParser.keyspaceNewName_return - Class in org.apache.cassandra.cli
-
- CliParser.keyspaceNewName_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
-
- CliParser.keyValuePair_return - Class in org.apache.cassandra.cli
-
- CliParser.keyValuePair_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePair_return
-
- CliParser.keyValuePairExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.keyValuePairExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
-
- CliParser.listStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.listStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.listStatement_return
-
- CliParser.newColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.newColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.newColumnFamily_return
-
- CliParser.operator_return - Class in org.apache.cassandra.cli
-
- CliParser.operator_return() - Constructor for class org.apache.cassandra.cli.CliParser.operator_return
-
- CliParser.password_return - Class in org.apache.cassandra.cli
-
- CliParser.password_return() - Constructor for class org.apache.cassandra.cli.CliParser.password_return
-
- CliParser.port_return - Class in org.apache.cassandra.cli
-
- CliParser.port_return() - Constructor for class org.apache.cassandra.cli.CliParser.port_return
-
- CliParser.replica_placement_strategy_return - Class in org.apache.cassandra.cli
-
- CliParser.replica_placement_strategy_return() - Constructor for class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
-
- CliParser.reversedExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.reversedExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.reversedExpr_return
-
- CliParser.root_return - Class in org.apache.cassandra.cli
-
- CliParser.root_return() - Constructor for class org.apache.cassandra.cli.CliParser.root_return
-
- CliParser.rowKey_return - Class in org.apache.cassandra.cli
-
- CliParser.rowKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowKey_return
-
- CliParser.rowLimitExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.rowLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
-
- CliParser.rowValue_return - Class in org.apache.cassandra.cli
-
- CliParser.rowValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowValue_return
-
- CliParser.setStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.setStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.setStatement_return
-
- CliParser.setTraceProbability_return - Class in org.apache.cassandra.cli
-
- CliParser.setTraceProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.setTraceProbability_return
-
- CliParser.showClusterName_return - Class in org.apache.cassandra.cli
-
- CliParser.showClusterName_return() - Constructor for class org.apache.cassandra.cli.CliParser.showClusterName_return
-
- CliParser.showKeyspaces_return - Class in org.apache.cassandra.cli
-
- CliParser.showKeyspaces_return() - Constructor for class org.apache.cassandra.cli.CliParser.showKeyspaces_return
-
- CliParser.showSchema_return - Class in org.apache.cassandra.cli
-
- CliParser.showSchema_return() - Constructor for class org.apache.cassandra.cli.CliParser.showSchema_return
-
- CliParser.showStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.showStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.showStatement_return
-
- CliParser.showVersion_return - Class in org.apache.cassandra.cli
-
- CliParser.showVersion_return() - Constructor for class org.apache.cassandra.cli.CliParser.showVersion_return
-
- CliParser.statement_return - Class in org.apache.cassandra.cli
-
- CliParser.statement_return() - Constructor for class org.apache.cassandra.cli.CliParser.statement_return
-
- CliParser.traceNextQuery_return - Class in org.apache.cassandra.cli
-
- CliParser.traceNextQuery_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceNextQuery_return
-
- CliParser.traceSessionId_return - Class in org.apache.cassandra.cli
-
- CliParser.traceSessionId_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceSessionId_return
-
- CliParser.tracingProbability_return - Class in org.apache.cassandra.cli
-
- CliParser.tracingProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.tracingProbability_return
-
- CliParser.truncateStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.truncateStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.truncateStatement_return
-
- CliParser.typeIdentifier_return - Class in org.apache.cassandra.cli
-
- CliParser.typeIdentifier_return() - Constructor for class org.apache.cassandra.cli.CliParser.typeIdentifier_return
-
- CliParser.updateColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.updateColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
-
- CliParser.updateKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.updateKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateKeyspace_return
-
- CliParser.useKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.useKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.useKeyspace_return
-
- CliParser.username_return - Class in org.apache.cassandra.cli
-
- CliParser.username_return() - Constructor for class org.apache.cassandra.cli.CliParser.username_return
-
- CliParser.value_return - Class in org.apache.cassandra.cli
-
- CliParser.value_return() - Constructor for class org.apache.cassandra.cli.CliParser.value_return
-
- CliSessionState - Class in org.apache.cassandra.cli
-
Used to hold the state for the CLI.
- CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
-
- CliUserHelp - Class in org.apache.cassandra.cli
-
- CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
-
- CliUtils - Class in org.apache.cassandra.cli
-
- CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
-
- clone() - Method in class org.apache.cassandra.config.CFMetaData
-
- clone() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.Allocator
-
Allocate a slice of the given length.
- clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- 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, move, and relocate operations have finished.
- cloneMe() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clones the column map.
- cloneMe() - Method in class org.apache.cassandra.db.EmptyColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- cloneMeShallow(ColumnFamily.Factory<T>, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with only tokenToEndpointMap.
- cloneShallow() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- cloneWith(KSMetaData, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
-
- cloneWithNewName(ByteBuffer) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- close() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- close() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
clean up any open resources
- close() - Method in class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- close() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Close the segment file.
- close() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- close() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- close() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- close() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Close this RecordWriter
to future operations, but not before
flushing out the batched mutations.
- close(Reporter) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- close() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- close() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Clean up all opened resources.
- close() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Closes this stream and frees resources associated with this stream.
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Closes this stream.
- close(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- close() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- close() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- close() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- close() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Closes the socket.
- close() - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- close() - Method in class org.apache.cassandra.tools.NodeProbe
-
- close() - Method in class org.apache.cassandra.transport.SimpleClient
-
- close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close() - Method in class org.apache.cassandra.utils.BloomFilter
-
- close(int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- 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 class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- close() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
-
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeAll() - Method in interface org.apache.cassandra.transport.Connection.Tracker
-
- closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- closeAndOpenReader() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeAndOpenReader(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeInternal() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cluster_name - Variable in class org.apache.cassandra.config.Config
-
- clusteringKeyColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- clusteringKeyDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- cmdCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
-
- code() - Method in exception org.apache.cassandra.exceptions.CassandraException
-
- code() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception code.
- code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- code() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- code() - Method in exception org.apache.cassandra.transport.ServerError
-
- codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- codec - Static variable in enum org.apache.cassandra.transport.DataType
-
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthChallenge
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
-
- codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ErrorMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.EventMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.OptionsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.PrepareMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.QueryMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ReadyMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.RegisterMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- collateColumns(ColumnFamily, List<? extends Iterator<Column>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateColumns(ColumnFamily, List<? extends Iterator<Column>>, IDiskAtomFilter, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, IDiskAtomFilter, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, Iterator<? extends OnDiskAtom>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
When there is only a single source of atoms, we can skip the collate step
- CollationController - Class in org.apache.cassandra.db
-
- CollationController(ColumnFamilyStore, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
-
- collection_literal() - Method in class org.apache.cassandra.cql3.CqlParser
-
- collection_type() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CollectionSerializer<T> - Class in org.apache.cassandra.serializers
-
- CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
-
- CollectionType<T> - Class in org.apache.cassandra.db.marshal
-
The abstract validator that is the base for maps, sets and lists.
- CollectionType(CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
-
- CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Attributes
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Operation
-
Collects the column specification for the bind variables of this operation.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Term
-
Collects the column specification for the bind variables in this Term.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
collects columns from reducedColumns into returnCF.
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- COLUMN - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COLUMN - Static variable in class org.apache.cassandra.cli.CliParser
-
- Column - Class in org.apache.cassandra.db
-
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
- Column(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.Column
-
- Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.Column
-
- column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- column_family - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
-
- columnComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- columnCount - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- columnCount - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
how many columns are there in the row
- ColumnCounter - Class in org.apache.cassandra.db.filter
-
- ColumnCounter(long) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter
-
- columnCounter(AbstractType<?>, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- columnCounter(AbstractType<?>, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columnCounter(AbstractType<?>, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- columnCounter() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- columnCounter() - Method in interface org.apache.cassandra.service.pager.SinglePartitionPager
-
- ColumnCounter.GroupByPrefix - Class in org.apache.cassandra.db.filter
-
- ColumnCounter.GroupByPrefix(long, CompositeType, int) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
A column counter that count only 1 for all the columns sharing a
given prefix of the key.
- columnDef - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- ColumnDefinition - Class in org.apache.cassandra.config
-
- ColumnDefinition(ByteBuffer, AbstractType<?>, Integer, ColumnDefinition.Type) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition(ByteBuffer, AbstractType<?>, IndexType, Map<String, String>, String, Integer, ColumnDefinition.Type) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition.Type - Enum in org.apache.cassandra.config
-
- columnDefs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The column definitions which this index is responsible for
- columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- columnFamily(String, String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource instance representing a column family.
- columnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- columnFamily - Variable in class org.apache.cassandra.cql.AbstractModification
-
- columnFamily - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- columnFamily - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- ColumnFamily - Class in org.apache.cassandra.db
-
A sorted map of columns.
- ColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.ColumnFamily
-
- columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
-
- columnFamily - Variable in class org.apache.cassandra.db.Truncation
-
- columnFamily - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
- columnFamily - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ColumnFamily.Factory<T extends ColumnFamily> - Class in org.apache.cassandra.db
-
- ColumnFamily.Factory() - Constructor for class org.apache.cassandra.db.ColumnFamily.Factory
-
- columnFamilyExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- ColumnFamilyMetrics - Class in org.apache.cassandra.metrics
-
- ColumnFamilyMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- columnFamilyName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- columnFamilyName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- ColumnFamilyNotDefinedException - Exception in org.apache.cassandra.db
-
- ColumnFamilyNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.ColumnFamilyNotDefinedException
-
- ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
values) as Cassandra rows (and respective columns) in a given
ColumnFamily.
- ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
- ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
-
- ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilySerializer - Class in org.apache.cassandra.db
-
- ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
-
- ColumnFamilySplit - Class in org.apache.cassandra.hadoop
-
- ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
Deprecated.
- ColumnFamilySplit(String, String, long, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilyStore - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.AbstractScanIterator() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
-
- ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
-
The MBean interface for ColumnFamilyStore
- ColumnFamilyType - Enum in org.apache.cassandra.db
-
column family type enum
- columnFilter - Variable in class org.apache.cassandra.db.DataRange
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- ColumnGroupMap - Class in org.apache.cassandra.cql3.statements
-
- ColumnGroupMap.Builder - Class in org.apache.cassandra.cql3.statements
-
- ColumnGroupMap.Builder(CompositeType, boolean, long) - Constructor for class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- 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
-
- ColumnIndex - Class in org.apache.cassandra.db
-
- ColumnIndex.Builder - Class in org.apache.cassandra.db
-
Help to create an index for a column family based on size of columns,
and write said columns to disk.
- ColumnIndex.Builder(ColumnFamily, ByteBuffer, DataOutput) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
-
- columnLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- columnMetadata(Map<ByteBuffer, ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
-
- columnName() - Method in class org.apache.cassandra.cli.CliParser
-
- columnName - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnName - Variable in class org.apache.cassandra.cql3.Operation
-
- columnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- ColumnNameBuilder - Interface in org.apache.cassandra.cql3
-
Build a potentially composite column name.
- ColumnNameHelper - Class in org.apache.cassandra.io.sstable
-
- ColumnNameHelper() - Constructor for class org.apache.cassandra.io.sstable.ColumnNameHelper
-
- columnOperation(List<Pair<ColumnIdentifier, Operation.RawUpdate>>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- columnOrSuperColumn() - Method in class org.apache.cassandra.cli.CliParser
-
- columnReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- columns - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- columns - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columns - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- ColumnSerializer - Class in org.apache.cassandra.db
-
- ColumnSerializer() - Constructor for class org.apache.cassandra.db.ColumnSerializer
-
- ColumnSerializer.CorruptColumnException - Exception in org.apache.cassandra.db
-
- ColumnSerializer.CorruptColumnException(String) - Constructor for exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- ColumnSerializer.Flag - Enum in org.apache.cassandra.db
-
Flag affecting deserialization behavior.
- columnsIndex - Variable in class org.apache.cassandra.db.ColumnIndex
-
- columnsIndex() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- ColumnSlice - Class in org.apache.cassandra.db.filter
-
- ColumnSlice(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice
-
- ColumnSlice.NavigableMapIterator - Class in org.apache.cassandra.db.filter
-
- ColumnSlice.NavigableMapIterator(NavigableMap<ByteBuffer, Column>, ColumnSlice[]) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
-
- ColumnSlice.Serializer - Class in org.apache.cassandra.db.filter
-
- ColumnSlice.Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- ColumnSpecification - Class in org.apache.cassandra.cql3
-
- ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- ColumnStats - Class in org.apache.cassandra.io.sstable
-
ColumnStats holds information about the columns for one row inside sstable
- ColumnStats(int, long, long, int, StreamingHistogram, List<ByteBuffer>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats
-
- ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
-
- columnToTuple(Column, CfDef, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert a column to a tuple
- command() - Method in class org.apache.cassandra.cli.CliParser
-
- command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- commandCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- commandDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- commandPendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- commands - Variable in class org.apache.cassandra.cli.CliUserHelp
-
- commands - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- commands - Variable in class org.apache.cassandra.tools.NodeToolHelp
-
- commandType - Variable in class org.apache.cassandra.db.ReadCommand
-
- COMMENT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cli.CliParser
-
- comment(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- Commit - Class in org.apache.cassandra.service.paxos
-
- Commit(ByteBuffer, UUID, ColumnFamily) - Constructor for class org.apache.cassandra.service.paxos.Commit
-
- commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
-
- Commit.CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- CommitLog - Class in org.apache.cassandra.db.commitlog
-
- commitlog_directory - Variable in class org.apache.cassandra.config.Config
-
- commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
-
- 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
-
- CommitLogAllocator - Class in org.apache.cassandra.db.commitlog
-
Performs the pre-allocation of commit log segments in a background thread.
- CommitLogAllocator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
-
- CommitLogArchiver() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
-
- CommitLogDescriptor(int, long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogDescriptor(long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogMetrics - Class in org.apache.cassandra.metrics
-
Metrics for commit log
- CommitLogMetrics(ICommitLogExecutorService, CommitLogAllocator) - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
-
- CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- CommitLogSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- CommitVerbHandler - Class in org.apache.cassandra.service.paxos
-
- CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- compact() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- COMPACTED_MARKER - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
-
- CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- COMPACTION_LOG - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- COMPACTION_OPTIONS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- compaction_preheat_key_cache - Variable in class org.apache.cassandra.config.Config
-
- COMPACTION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.CFPropDefs
-
- compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
-
- CompactionController - Class in org.apache.cassandra.db.compaction
-
Manage compaction options.
- CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
Constructor that subclasses may use when overriding shouldPurge to not need overlappingTree
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionInfo - Class in org.apache.cassandra.db.compaction
-
Implements serializable to allow structured info to be returned via JMX.
- CompactionInfo(CFMetaData, OperationType, long, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(CFMetaData, OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
-
- CompactionInfo.Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- CompactionInterruptedException - Exception in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException(CompactionInfo) - Constructor for exception org.apache.cassandra.db.compaction.CompactionInterruptedException
-
- CompactionIterable - Class in org.apache.cassandra.db.compaction
-
- CompactionIterable(OperationType, List<ICompactionScanner>, CompactionController) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
-
- CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
-
- CompactionIterable.Reducer() - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- CompactionLogCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CompactionManager - Class in org.apache.cassandra.db.compaction
-
A singleton which manages a private executor of ongoing compactions.
- CompactionManager() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager
-
- CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
-
- CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
-
- CompactionMetrics - Class in org.apache.cassandra.metrics
-
Metrics for compaction.
- CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
-
- compactionStrategyClass - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyClass(Class<? extends AbstractCompactionStrategy>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyClass - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompactionTask - Class in org.apache.cassandra.db.compaction
-
- CompactionTask(ColumnFamilyStore, Iterable<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
- compactionType - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- compactionType - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- compactValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- compactValueDef(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- comparator() - Method in class org.apache.cassandra.cli.CliParser
-
- comparator - Variable in class org.apache.cassandra.config.CFMetaData
-
- comparator - Variable in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- comparator - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
-
- comparator - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- comparator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- comparators - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- comparatorType() - Method in class org.apache.cassandra.cql.CqlParser
-
- comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
-
- compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- compare(SSTableReader, SSTableReader) - Method in class org.apache.cassandra.io.sstable.SSTableReader.SizeComparator
-
- compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
determine which endpoint started up earlier
- compareIdTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- compareLongs(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.LongType
-
- compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Compare two ByteBuffer at specified offsets for length.
- compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
-
- compareTo(RowCacheKey) - Method in class org.apache.cassandra.cache.RowCacheKey
-
- compareTo(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- compareTo(RowPosition) - Method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(IPartitioner, ByteBuffer, RowPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- compareTo(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- compareTo(Token<BigInteger>) - Method in class org.apache.cassandra.dht.BigIntegerToken
-
- compareTo(Token<byte[]>) - Method in class org.apache.cassandra.dht.BytesToken
-
- compareTo(Token<ByteBuffer>) - Method in class org.apache.cassandra.dht.LocalToken
-
- compareTo(Token<Long>) - Method in class org.apache.cassandra.dht.LongToken
-
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- compareTo(Token<String>) - Method in class org.apache.cassandra.dht.StringToken
-
- compareTo(Token<T>) - Method in class org.apache.cassandra.dht.Token
-
This determines the comparison for node destination purposes.
- compareTo(RowPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
-
- compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
-
- compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- compareTo(CounterId) - Method in class org.apache.cassandra.utils.CounterId
-
- compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
-
- compareTo(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- 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
-
- COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- complete(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
- complete() - 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.StreamSession
-
Check if session is completed on receiving StreamMessage.Type.COMPLETE
message.
- complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for file at sequenceNumber
.
- completed(R) - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- completedTaskCount - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Number of completed tasks
- completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Number of completed compactions since server [re]start
- completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of completed tasks.
- CompleteMessage - Class in org.apache.cassandra.streaming.messages
-
- CompleteMessage() - Constructor for class org.apache.cassandra.streaming.messages.CompleteMessage
-
- completeTree() - Method in class org.apache.cassandra.repair.Validator
-
- Component - Class in org.apache.cassandra.io.sstable
-
SSTables are made up of multiple components in separate files.
- Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component(Component.Type, String) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component.Type - Enum in org.apache.cassandra.io.sstable
-
- COMPONENT_DATA - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_DIGEST - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_FILTER - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_INDEX - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_STATS - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- componentCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Returns the number of component already added to this builder.
- componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- componentIndex - Variable in class org.apache.cassandra.config.ColumnDefinition
-
- 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
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
Deconstructs a composite type to a Tuple.
- COMPOSITE_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
-
- CompositesIndex - Class in org.apache.cassandra.db.index.composites
-
Base class for secondary indexes where composites are involved.
- CompositesIndex() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex
-
- CompositesIndex.IndexedEntry - Class in org.apache.cassandra.db.index.composites
-
- CompositesIndex.IndexedEntry(DecoratedKey, ByteBuffer, long, ByteBuffer, ColumnNameBuilder) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- CompositesIndexOnClusteringKey - Class in org.apache.cassandra.db.index.composites
-
Index on a CLUSTERING_KEY column definition.
- CompositesIndexOnClusteringKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- CompositesIndexOnPartitionKey - Class in org.apache.cassandra.db.index.composites
-
Index on a PARTITION_KEY column definition.
- CompositesIndexOnPartitionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- CompositesIndexOnRegular - Class in org.apache.cassandra.db.index.composites
-
Index on a REGULAR column definition on a composite type.
- CompositesIndexOnRegular() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- CompositesSearcher - Class in org.apache.cassandra.db.index.composites
-
- CompositesSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.composites.CompositesSearcher
-
- compositesToGroup - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- CompositeType - Class in org.apache.cassandra.db.marshal
-
- CompositeType.Builder - Class in org.apache.cassandra.db.marshal
-
- CompositeType.Builder(CompositeType) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- CompositeType.Builder(CompositeType, List<ByteBuffer>, byte[]) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- compress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- CompressedInputStream - Class in org.apache.cassandra.streaming.compress
-
InputStream which reads data from underlining source with given
CompressionInfo
.
- CompressedInputStream(InputStream, CompressionInfo, boolean) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- CompressedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
-
CRAR extends RAR to transparently uncompress blocks from the file into RAR.buffer.
- CompressedRandomAccessReader(String, CompressionMetadata, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- CompressedSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
-
- CompressedSequentialWriter(File, String, boolean, CompressionParameters, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
-
Class to hold a mark to the position of the file
- CompressedSequentialWriter.CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
-
- CompressedStreamReader - Class in org.apache.cassandra.streaming.compress
-
StreamReader that reads from streamed compressed SSTable
- CompressedStreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressedStreamWriter - Class in org.apache.cassandra.streaming.compress
-
StreamWriter for compressed SSTable.
- CompressedStreamWriter(SSTableReader, Collection<Pair<Long, Long>>, CompressionInfo, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- CompressedThrottledReader - Class in org.apache.cassandra.io.compress
-
- CompressedThrottledReader(String, CompressionMetadata, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
-
- COMPRESSION_PARAMETERS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressionInfo - Class in org.apache.cassandra.streaming.compress
-
Container that carries compression parameters and chunks to decompress data from stream.
- CompressionInfo(CompressionMetadata.Chunk[], CompressionParameters) - Constructor for class org.apache.cassandra.streaming.compress.CompressionInfo
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- CompressionMetadata - Class in org.apache.cassandra.io.compress
-
Holds metadata about compressed file
- CompressionMetadata.Chunk - Class in org.apache.cassandra.io.compress
-
Holds offset and length of the file chunk
- CompressionMetadata.Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- CompressionMetadata.Writer - Class in org.apache.cassandra.io.compress
-
- compressionParameters - Variable in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters(CompressionParameters) - Method in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters() - Method in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompressionParameters - Class in org.apache.cassandra.io.compress
-
- CompressionParameters(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- compressionRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Current compression ratio for all SSTables
- compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- computeNext() - Method in class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
-
- computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
Find the next TreeRange.
- computeOldShardMerger(ByteBuffer, List<CounterId.CounterIdRecord>, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Compute a new context such that if applied to context yields the same
total but with old local counter ids nulified and there content merged to
the current localCounterId.
- concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- concurrent_compactors - 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
-
- concurrent_writes - Variable in class org.apache.cassandra.config.Config
-
- ConcurrentLinkedHashCache<K extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
-
Wrapper so CLHM can implement ICache interface.
- CONDITION - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONDITION - Static variable in class org.apache.cassandra.cli.CliParser
-
- condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
-
- conf - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- conf - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- CONFIG - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONFIG - Static variable in class org.apache.cassandra.cli.CliParser
-
- Config - Class in org.apache.cassandra.config
-
A class that contains configuration properties for the cassandra node it runs within.
- Config() - Constructor for class org.apache.cassandra.config.Config
-
- Config.CommitLogSync - Enum in org.apache.cassandra.config
-
- Config.DiskAccessMode - Enum in org.apache.cassandra.config
-
- Config.DiskFailurePolicy - Enum in org.apache.cassandra.config
-
- Config.InternodeCompression - Enum in org.apache.cassandra.config
-
- Config.RequestSchedulerId - Enum in org.apache.cassandra.config
-
- 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
-
- ConfigurationException - Exception in org.apache.cassandra.exceptions
-
- ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationLoader - Interface in org.apache.cassandra.config
-
- confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
-
Establish a thrift connection to cassandra instance
- CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
-
- connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- Connection - Class in org.apache.cassandra.transport
-
- Connection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
-
- connection - Variable in class org.apache.cassandra.transport.Message
-
- connection() - Method in class org.apache.cassandra.transport.Message
-
- connection - Variable in class org.apache.cassandra.transport.SimpleClient
-
- Connection.Factory - Interface in org.apache.cassandra.transport
-
- Connection.Tracker - Interface in org.apache.cassandra.transport
-
- connectionComplete(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
The connection associated with @param socket is permanently finished.
- 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.
- connectStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- consistency - Variable in class org.apache.cassandra.cql.BatchStatement
-
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- consistency - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliParser
-
- ConsistencyLevel - Enum in org.apache.cassandra.db
-
- consistencyLevel - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- consistencyLevelStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- constant() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Constants - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for constants.
- Constants() - Constructor for class org.apache.cassandra.cql3.Constants
-
- Constants.Adder - Class in org.apache.cassandra.cql3
-
- Constants.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
-
- Constants.Deleter - Class in org.apache.cassandra.cql3
-
- Constants.Deleter(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
-
- Constants.Literal - Class in org.apache.cassandra.cql3
-
- Constants.Marker - Class in org.apache.cassandra.cql3
-
- Constants.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
-
- Constants.Setter - Class in org.apache.cassandra.cql3
-
- Constants.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
-
- Constants.Substracter - Class in org.apache.cassandra.cql3
-
- Constants.Substracter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
-
- Constants.Type - Enum in org.apache.cassandra.cql3
-
- Constants.Value - Class in org.apache.cassandra.cql3
-
A constant value, i.e.
- Constants.Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
-
- construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Constructs an instance of the given class, which must have a no-arg or default constructor.
- contains(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Check to see if a certain ReplayPosition is contained by this segment file.
- contains(RowPosition) - Method in class org.apache.cassandra.db.DataRange
-
- contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.Bounds
-
- contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
-
- contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- contains(T) - Method in class org.apache.cassandra.dht.Range
-
Helps determine if a given point on the DHT ring is contained
in the range in question.
- 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
-
- containsCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- containsKey(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- containsKey(K) - Method in interface org.apache.cassandra.cache.ICache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- contents() - Method in class org.apache.cassandra.db.Memtable
-
- contentSerializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- contextManager - Static variable in class org.apache.cassandra.db.CounterColumn
-
- controller - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliParser
-
- convertOldStrategyName(String) - Static method in class org.apache.cassandra.config.KSMetaData
-
- convertPropertyMap(Maps.Literal) - Method in class org.apache.cassandra.cql3.CqlParser
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is part of IFailureDetectionEventListener interface.
- convict(InetAddress, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
-
Convict the specified endpoint.
- convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
-
- convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
called from gossiper when it notices a node is not responding.
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.RepairSession
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.streaming.StreamSession
-
- coordinator - Variable in class org.apache.cassandra.tracing.TraceState
-
- copy() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Clone this builder.
- copy() - Method in class org.apache.cassandra.db.DeletionInfo
-
- copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy() - Method in class org.apache.cassandra.db.ReadCommand
-
- copy() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- copyWithNewSSTableLevel(SSTableMetadata, int) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
Deprecated.
- CorruptBlockException - Exception in org.apache.cassandra.io.compress
-
- CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
-
- CorruptSSTableException(Exception, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- CorruptSSTableException(Exception, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COUNT - Static variable in class org.apache.cassandra.cli.CliParser
-
- count(Column, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- count(Column, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
- count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The total number of bytes initially available in the byte array
buf
.
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
The number of bytes written.
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- countAll(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- countAllBatches() - Method in class org.apache.cassandra.db.BatchlogManager
-
- countAllBatches() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
Counts all batches currently in the batchlog.
- countCQL3Rows() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- countCQL3Rows - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- COUNTER_ID_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- COUNTER_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- CounterColumn - Class in org.apache.cassandra.db
-
A column that represents a partitioned counter.
- CounterColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, long, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- 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.ContextState(ByteBuffer, int) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
-
- CounterContext.ContextState(ByteBuffer) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
-
- counterid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- CounterId - Class in org.apache.cassandra.utils
-
- CounterId.CounterIdRecord - Class in org.apache.cassandra.utils
-
- CounterId.CounterIdRecord(CounterId, long) - Constructor for class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- CounterId.OneShotRenewer - Class in org.apache.cassandra.utils
-
- CounterId.OneShotRenewer() - Constructor for class org.apache.cassandra.utils.CounterId.OneShotRenewer
-
- CounterIdCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CounterMutation - Class in org.apache.cassandra.db
-
- CounterMutation(RowMutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
-
- 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
-
- CounterUpdateColumn - Class in org.apache.cassandra.db
-
A counter update while it hasn't been applied yet by the leader replica.
- CounterUpdateColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
-
- CounterUpdateColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
-
- countPaged(String, String, ByteBuffer, SliceQueryFilter, ConsistencyLevel, int, long) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
- countStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- CQL3Type - Interface in org.apache.cassandra.cql3
-
- CQL3Type.Collection - Class in org.apache.cassandra.cql3
-
- CQL3Type.Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
-
- CQL3Type.Custom - Class in org.apache.cassandra.cql3
-
- CQL3Type.Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- CQL3Type.Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- CQL3Type.Native - Enum in org.apache.cassandra.cql3
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- CqlLexer - Class in org.apache.cassandra.cql
-
- CqlLexer() - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer - Class in org.apache.cassandra.cql3
-
- CqlLexer() - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
binded variable values) as CQL rows (and respective columns) in a given
ColumnFamily.
- CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- CqlPagingInputFormat - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- CqlPagingInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- CqlPagingRecordReader - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop RecordReader read the values return from the CQL query
It use CQL key range query to page through the wide rows.
- CqlPagingRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- CqlParser - Class in org.apache.cassandra.cql
-
- CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql.CqlParser
-
- CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlParser
-
- CqlParser - Class in org.apache.cassandra.cql3
-
- CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlParser.comparatorType_return - Class in org.apache.cassandra.cql
-
- CqlParser.comparatorType_return() - Constructor for class org.apache.cassandra.cql.CqlParser.comparatorType_return
-
- CqlParser.username_return - Class in org.apache.cassandra.cql3
-
- CqlParser.username_return() - Constructor for class org.apache.cassandra.cql3.CqlParser.username_return
-
- CQLStatement - Class in org.apache.cassandra.cql
-
- CQLStatement(StatementType, Object, int) - Constructor for class org.apache.cassandra.cql.CQLStatement
-
- cqlStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CQLStatement - Interface in org.apache.cassandra.cql3
-
- CqlStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
A row from a standard CF will be returned as nested tuples:
(((key1, value1), (key2, value2)), ((name1, val1), (name2, val2))).
- CqlStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
- CqlStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
- CRC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of CREATE USER query (also may be called on startup, see seedSuperuserOptions method).
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long) - Method in class org.apache.cassandra.cache.SerializingCacheProvider
-
- CREATE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CREATE - Static variable in class org.apache.cassandra.cli.CliParser
-
- create(String, String) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- create(String, String) - Method in interface org.apache.cassandra.cql3.functions.Function.Factory
-
- create(List<Term>) - Static method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- create(Term) - Static method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- create(ByteBuffer, ByteBuffer, long, int, CFMetaData) - Static method in class org.apache.cassandra.db.Column
-
- create(String, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(int, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(boolean, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(double, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(ByteBuffer, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(InetAddress, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(CFMetaData, boolean) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
Returns a (initially empty) column map whose columns are sorted
according to the provided comparator.
- create(CFMetaData) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String, String) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
- create() - Method in interface org.apache.cassandra.db.columniterator.IColumnIteratorFactory
-
- create(DataInput, ByteBuffer) - Static method in exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- create(ColumnFamilyStore, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(ColumnFamilyStore, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(long, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates an initial counter context with an initial value for the local node.
- create(CounterId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext
-
- create(ByteBuffer, ByteBuffer, long, long, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.CounterColumn
-
- create(int, long, String...) - Static method in class org.apache.cassandra.db.DeletedColumn
-
- create(String, String) - Static method in class org.apache.cassandra.db.Directories
-
- create(ByteBuffer, ByteBuffer, long, int, int, int, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.ExpiringColumn
-
- create(ColumnFamilyStore, DataRange, List<IndexExpression>, int, boolean, long) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- create(ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- create(String, ByteBuffer, String, long, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.ReadCommand
-
- create(long, DeletionTime, ColumnIndex) - Static method in class org.apache.cassandra.db.RowIndexEntry
-
- create(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Create metadata about given compressed file including uncompressed data length, chunk size
and list of the chunk offsets of the compressed data.
- create(Map<? extends CharSequence, ? extends CharSequence>) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(ChannelBuffer) - Static method in class org.apache.cassandra.transport.Frame
-
- create(Message.Type, int, int, EnumSet<Frame.Header.Flag>, ChannelBuffer) - Static method in class org.apache.cassandra.transport.Frame
-
- create(C, C) - Static method in class org.apache.cassandra.utils.Interval
-
- create(C, C, D) - Static method in class org.apache.cassandra.utils.Interval
-
- create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
-
- create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>, Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Creates all storage-related directories.
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Connects to the given server:port and returns a client based on the given socket that points to the configured
keyspace, and is logged in with the configured credentials.
- createCfamColumns(CreateColumnFamilyStatement) - Method in class org.apache.cassandra.cql.CqlParser
-
- createCfamColumnValidator() - Method in class org.apache.cassandra.cql.CqlParser
-
- createCfamKeywordArgument() - Method in class org.apache.cassandra.cql.CqlParser
-
- createCollector(AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- createCollector(Collection<SSTableReader>, AbstractType<?>, int) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
create commutative column
- createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
create commutative column
- createColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- CreateColumnFamilyStatement - Class in org.apache.cassandra.cql
-
A CREATE COLUMNFAMILY
parsed from a CQL query statement.
- CreateColumnFamilyStatement(String) - Constructor for class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- createColumnFamilyStore(Keyspace, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, IPartitioner, CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompactionStrategyInstance(ColumnFamilyStore) - Method in class org.apache.cassandra.config.CFMetaData
-
- createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createFilter(int, IBitSet) - Method in class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
-
- createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- CreateIndexStatement - Class in org.apache.cassandra.cql
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(String, String, Term) - Constructor for class org.apache.cassandra.cql.CreateIndexStatement
-
- createIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(CFName, String, ColumnIdentifier, boolean, boolean, String) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- createInRelation(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.Relation
-
- createInstance(ColumnFamilyStore, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
This is the primary way to create a secondary index instance for a CF column.
- createKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, KSPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- createLinks(String) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- createMessage() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- createMessage() - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceReply
-
- createMessage() - Method in class org.apache.cassandra.db.ReadCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RowMutation
-
- createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.RowMutation
-
- createMessage() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- createMessage() - Method in class org.apache.cassandra.db.TruncateResponse
-
- createMessage() - Method in class org.apache.cassandra.db.Truncation
-
- createMessage() - Method in class org.apache.cassandra.db.WriteResponse
-
- createMessage() - Method in class org.apache.cassandra.repair.messages.RepairMessage
-
- createMessage(boolean, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
Create serialized message.
- createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- createMetricName(String) - Method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
-
Create MetricName
from given metric name.
- createReader(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
-
- createReader(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- createReader(String) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- createReplicationStrategy(KSMetaData) - Method in class org.apache.cassandra.db.Keyspace
-
- createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Called at query time
Creates a implementation specific searcher instance for this index type
- createShuffleBatchInsert(Collection<String>, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.Shuffle
-
Create and return a CQL batch insert statement for a set of token relocations.
- createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
-
- createSSTableAndLengthPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- createTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateTableStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE TABLE
parsed from a CQL query statement.
- CreateTableStatement(CFName, CFPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- CreateTableStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTableStatement.RawStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- 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
-
- createTracingSession() - Method in class org.apache.cassandra.service.QueryState
-
- createTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTriggerStatement(CFName, String, String) - Constructor for class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- createUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateUserStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateUserStatement(String, UserOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- 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, int, SSTableReader) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- createWriter(ColumnFamilyStore, long) - Method in class org.apache.cassandra.streaming.StreamReader
-
- creationTime() - Method in class org.apache.cassandra.db.Memtable
-
- credentials - Variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- CredentialsMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- CredentialsMessage() - Constructor for class org.apache.cassandra.transport.messages.CredentialsMessage
-
- cross_node_timeout - Variable in class org.apache.cassandra.config.Config
-
- CURRENT - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- current - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- current - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- current_version - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
Increment this number if there is a changes in the commit log disc layout or MessagingVersion changes.
- current_version - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
Streaming protocol version
- CURRENT_VERSION - Static variable in class org.apache.cassandra.transport.Server
-
current version of the native protocol we support
- 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).
- currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentLimit() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentTasks - Variable in class org.apache.cassandra.db.Directories.DataDirectory
-
- CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
- 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
-
- 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.CustomFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
-
- 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
-
- CustomTThreadPoolServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
-
- D - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- D - Static variable in class org.apache.cassandra.cql.CqlParser
-
- D - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- D - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DATA - Static variable in class org.apache.cassandra.io.sstable.Component
-
- data - Variable in class org.apache.cassandra.utils.Interval
-
- data_file_directories - Variable in class org.apache.cassandra.config.Config
-
- DatabaseDescriptor - Class in org.apache.cassandra.config
-
- DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
-
- datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
- DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Keyspace, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- DatacenterWriteResponseHandler - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
- DatacenterWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Keyspace, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- dataFileLocations - Static variable in class org.apache.cassandra.db.Directories
-
- 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.ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- DataIntegrityMetadata.ChecksumWriter - Class in org.apache.cassandra.io.util
-
- DataIntegrityMetadata.ChecksumWriter(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- DataOutputBuffer - Class in org.apache.cassandra.io.util
-
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing
its buffer so copies can be avoided.
- DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- DataRange - Class in org.apache.cassandra.db
-
Groups key range and column filter for range queries.
- DataRange(AbstractBounds<RowPosition>, IDiskAtomFilter) - Constructor for class org.apache.cassandra.db.DataRange
-
- dataRange - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
-
- DataRange.Paging - Class in org.apache.cassandra.db
-
- DataRange.Paging(AbstractBounds<RowPosition>, SliceQueryFilter, ByteBuffer, ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.db.DataRange.Paging
-
- DataResource - Class in org.apache.cassandra.auth
-
The primary type of resource in Cassandra.
- dataResource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- dataSize() - Method in class org.apache.cassandra.db.Column
-
- dataSize() - Method in class org.apache.cassandra.db.CounterColumn
-
- dataSize() - Method in class org.apache.cassandra.db.DeletionInfo
-
- dataSize() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- dataSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- dataSize - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- DataTracker - Class in org.apache.cassandra.db
-
- DataTracker(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.DataTracker
-
- DataTracker.SSTableIntervalTree - Class in org.apache.cassandra.db
-
- DataType - Enum in org.apache.cassandra.transport
-
- dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- dateStringToTimestamp(String) - Static method in class org.apache.cassandra.db.marshal.DateType
-
- dateStringToTimestamp(String) - Static method in class org.apache.cassandra.db.marshal.TimestampType
-
- DateType - Class in org.apache.cassandra.db.marshal
-
- dc_local_address - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Node
-
- dc_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- dcLocalReadRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- deactivate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to stop and destroy the daemon in one shot.
- deallocate() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- debug - Variable in class org.apache.cassandra.cli.CliSessionState
-
- debug(String) - Method in 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
-
- 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(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
-
- DecimalDigit - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DecimalDigit - Static variable in class org.apache.cassandra.cli.CliParser
-
- DecimalSerializer - Class in org.apache.cassandra.serializers
-
- DecimalSerializer() - Constructor for class org.apache.cassandra.serializers.DecimalSerializer
-
- DecimalType - Class in org.apache.cassandra.db.marshal
-
- decode(ChannelBuffer, int) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
-
- decode(ChannelBuffer, int) - Method in interface org.apache.cassandra.transport.CBCodec
-
- decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.apache.cassandra.transport.Frame.Decoder
-
- decode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Frame.Decompressor
-
- decode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Message.ProtocolDecoder
-
- decode(ChannelBuffer) - Method in class org.apache.cassandra.transport.OptionCodec
-
- decodeEntry(DecoratedKey, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- decodeEntry(DecoratedKey, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- decodeEntry(DecoratedKey, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- decodeEntry(DecoratedKey, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- decodeOne(ChannelBuffer) - Method in class org.apache.cassandra.transport.OptionCodec
-
- 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
-
- decompose(Long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- 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(Object...) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
decomposes a uuid into raw bytes.
- decompress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- deconstruct(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- DecoratedKey - Class in org.apache.cassandra.db
-
Represents a decorated key, handy for certain operations
where just working with strings gets slow.
- DecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.DecoratedKey
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- decorateKey(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Transform key to object representation of the on-disk format.
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- DECR - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DECR - Static variable in class org.apache.cassandra.cli.CliParser
-
- DEFAULT - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- DEFAULT_BUCKET_HIGH - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_BUCKET_LOW - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- DEFAULT_CACHING_STRATEGY - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_CHUNK_LENGTH - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- DEFAULT_COLUMN_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_COMPRESSOR - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- DEFAULT_CQL_PAGE_LIMIT - Static variable in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- DEFAULT_CQL_VERSION - Static variable in class org.apache.cassandra.service.ClientState
-
- DEFAULT_CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- default_dc_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- DEFAULT_DCLOCAL_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_DEFAULT_TIME_TO_LIVE - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_GC_GRACE_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_HOST - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- DEFAULT_INDEX_INTERVAL - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_INPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- DEFAULT_JMX_PORT - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- DEFAULT_KEY_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_KEY_NAME - Static variable in class org.apache.cassandra.cql.QueryProcessor
-
- DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_MAX_FRAME_SIZE - Static variable in class org.apache.cassandra.cli.transport.FramedTransportFactory
-
- DEFAULT_MIN_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_MIN_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- DEFAULT_OUTPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- DEFAULT_POPULATE_IO_CACHE_ON_FLUSH - Static variable in class org.apache.cassandra.config.CFMetaData
-
- default_rack_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_REPLICATE_ON_WRITE - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_SPECULATIVE_RETRY - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_SSTABLE_SIZE - Static variable in class org.apache.cassandra.tools.StandaloneSplitter
-
- DEFAULT_SUPERUSER_NAME - Static variable in class org.apache.cassandra.auth.Auth
-
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- 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_VALUE_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- defaultConsistency - Static variable in class org.apache.cassandra.cql.AbstractModification
-
- DefaultDouble - Class in org.apache.cassandra.utils
-
- DefaultDouble(double) - Constructor for class org.apache.cassandra.utils.DefaultDouble
-
- DefaultInteger - Class in org.apache.cassandra.utils
-
- DefaultInteger(int) - Constructor for class org.apache.cassandra.utils.DefaultInteger
-
- DefaultNameFactory - Class in org.apache.cassandra.metrics
-
MetricNameFactory that generates default MetricName of metrics.
- DefaultNameFactory(String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
-
- DefaultNameFactory(String, String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
-
- defaultTimeToLive(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- defaultUser() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- defaultValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
-
- defined - Variable in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- DefinitionsUpdateVerbHandler - Class in org.apache.cassandra.db
-
Called when node receives updated schema state from the schema migration coordinator node.
- DefinitionsUpdateVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
-
- definitionType - Static variable in class org.apache.cassandra.cql3.CFDefinition
-
- DeflateCompressor - Class in org.apache.cassandra.io.compress
-
- DefsTables - Class in org.apache.cassandra.db
-
SCHEMA_{KEYSPACES, COLUMNFAMILIES, COLUMNS}_CF are used to store Keyspace/ColumnFamily attributes to make schema
load/distribution easy, it replaces old mechanism when local migrations where serialized, stored in system.Migrations
and used for schema distribution.
- DefsTables() - Constructor for class org.apache.cassandra.db.DefsTables
-
- DEL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DEL - Static variable in class org.apache.cassandra.cli.CliParser
-
- delColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- delete(DeletionTime) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- delete(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- delete(RangeTombstone) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- delete(DeletionTime) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- delete(RangeTombstone) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- delete(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- delete(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
-
- delete(DeletionTime) - Method in class org.apache.cassandra.db.ColumnFamily
-
- delete(RangeTombstone) - Method in class org.apache.cassandra.db.ColumnFamily
-
- delete(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
-
- delete(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- delete(CompositesIndex.IndexedEntry) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- delete(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
Delete a column from the index
- delete(DecoratedKey) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
cleans up deleted columns from cassandra cleanup compaction
- delete(String, long) - Method in class org.apache.cassandra.db.RowMutation
-
- delete(String, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
-
- 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
-
- deleteAsync(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- DeletedColumn - Class in org.apache.cassandra.db
-
- DeletedColumn(ByteBuffer, int, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
-
- DeletedColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
-
- deleteFromIndexes(DecoratedKey, List<Column>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Delete all columns from all indexes for this row.
- deleteFromSchema(RowMutation, String, long) - Method in class org.apache.cassandra.config.ColumnDefinition
-
Drop specified column from the schema using given row.
- deleteFromSchema(RowMutation, String, long) - Method in class org.apache.cassandra.config.TriggerDefinition
-
Drop specified trigger from the schema using given row.
- deleteHintsForEndpoint(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- deleteHintsForEndpoint(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- deleteHintsForEndpoint(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
Nuke all hints from this node to `ep`.
- deleteOp() - Method in class org.apache.cassandra.cql3.CqlParser
-
- deleteRange(String, ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
-
- deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deletes all files and subdirectories under "dir".
- deleteSelection() - Method in class org.apache.cassandra.cql3.CqlParser
-
- deleteStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- DeleteStatement - Class in org.apache.cassandra.cql
-
A DELETE
parsed from a CQL query statement.
- DeleteStatement(List<Term>, String, String, String, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql.DeleteStatement
-
- deleteStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DeleteStatement - Class in org.apache.cassandra.cql3.statements
-
A DELETE
parsed from a CQL query statement.
- DeleteStatement.Parsed - Class in org.apache.cassandra.cql3.statements
-
- DeleteStatement.Parsed(CFName, Attributes.Raw, List<Operation.RawDeletion>, List<Relation>, List<Pair<ColumnIdentifier, Operation.RawUpdate>>) - Constructor for class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
-
- deleteUser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Deletes the user from AUTH_KS.USERS_CF.
- deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleting - Variable in class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- DELETION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- deletionInfo - Variable in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- deletionInfo() - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- deletionInfo() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- deletionInfo() - Method in class org.apache.cassandra.db.ColumnFamily
-
- DeletionInfo - Class in org.apache.cassandra.db
-
- DeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
-
- DeletionInfo(DeletionTime) - Constructor for class org.apache.cassandra.db.DeletionInfo
-
- DeletionInfo(ByteBuffer, ByteBuffer, Comparator<ByteBuffer>, long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
-
- DeletionInfo(RangeTombstone, Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.DeletionInfo
-
- DeletionInfo.InOrderTester - Class in org.apache.cassandra.db
-
This object allow testing whether a given column (name/timestamp) is deleted
or not by this DeletionInfo, assuming that the column given to this
object are passed in forward or reversed comparator sorted order.
- DeletionInfo.Serializer - Class in org.apache.cassandra.db
-
- DeletionInfo.Serializer() - Constructor for class org.apache.cassandra.db.DeletionInfo.Serializer
-
- DeletionTime - Class in org.apache.cassandra.db
-
- DeletionTime(long, int) - Constructor for class org.apache.cassandra.db.DeletionTime
-
- deletionTime() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
-
- deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- delKeyspace() - Method in class org.apache.cassandra.cli.CliParser
-
- delStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- delta() - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- deque - Variable in class org.apache.cassandra.utils.BoundedStatsDeque
-
- desc - Variable in class org.apache.cassandra.cache.KeyCacheKey
-
- desc - Variable in exception org.apache.cassandra.exceptions.RepairException
-
- desc - Variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- desc - Variable in class org.apache.cassandra.repair.RepairJob
-
- desc - Variable in class org.apache.cassandra.repair.StreamingRepairTask
-
Repair session ID that this streaming task belongs
- desc - Variable in class org.apache.cassandra.repair.Validator
-
- desc - Variable in class org.apache.cassandra.streaming.StreamReader
-
- DESCRIBE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DESCRIBE - Static variable in class org.apache.cassandra.cli.CliParser
-
- describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_partitioner() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_schema_versions() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_snitch() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
-
Deprecated.
- describe_splits_ex(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_token_map() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_version() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describeCluster() - Method in class org.apache.cassandra.cli.CliParser
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate the deltas between tokens in the ring in order to compare
relative sizes.
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- describeRing(String) - Method in class org.apache.cassandra.service.StorageService
-
The TokenRange for a given keyspace.
- describeRing(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- describeRingJMX(String) - Method in class org.apache.cassandra.service.StorageService
-
The same as describeRing(String)
but converts TokenRange to the String for JMX compatibility
- describeRingJMX(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
The same as describeRing(String)
but converts TokenRange to the String for JMX compatibility
- describeSchemaVersions() - Static method in class org.apache.cassandra.service.StorageProxy
-
initiate a request/response session with each live node to check whether or not everybody is using the same
migration id.
- describeTable() - Method in class org.apache.cassandra.cli.CliParser
-
- description - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- description - Variable in class org.apache.cassandra.streaming.StreamResultFuture
-
- description() - Method in class org.apache.cassandra.streaming.StreamSession
-
- description - Variable in class org.apache.cassandra.streaming.StreamState
-
- descriptor - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- Descriptor - Class in org.apache.cassandra.io.sstable
-
A SSTable is described by the keyspace and column family it contains data
for, a generation (where higher generations contain more recent data) and
an alphabetic version string.
- Descriptor(File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
A descriptor that assumes CURRENT_VERSION.
- Descriptor(String, File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
- Descriptor(Descriptor.Version, File, String, String, int, boolean) - 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.io.sstable
-
- Descriptor.Version(String) - Constructor for class org.apache.cassandra.io.sstable.Descriptor.Version
-
- deserialize(DataInputStream, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- deserialize(int) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserialize(DataInput, ColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserialize(DataInput, ColumnFamily.Factory, ColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- deserialize(DataInput, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- deserialize(DataInput, ColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- deserialize(DataInput, int, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- deserialize(DataInput, int, AbstractType<?>) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- deserialize(DataInput, int, AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.db.filter.QueryPath
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- deserialize(DataInput, int, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- deserialize(DataInput, int, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- deserialize(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- deserialize(DataInput, int, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- deserialize(DataInput) - Method in interface org.apache.cassandra.io.ISerializer
-
Deserialize from the specified DataInput instance.
- deserialize(DataInput, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Deserialize into the specified DataInputStream instance.
- deserialize(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- deserialize(DataInputStream, IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- deserialize(Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
deserializes the metadata
returns a pair containing the part of the metadata meant to be kept-in memory and the part
that should not.
- deserialize(Descriptor, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- deserialize(DataInputStream, Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- deserialize(DataInputStream, Descriptor, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- deserialize(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- deserialize(DataInputStream, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- deserialize(DataInputStream, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- deserialize(ByteBuffer) - Static method in class org.apache.cassandra.service.pager.PagingState
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- deserialize(ReadableByteChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- deserialize(ReadableByteChannel, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- deserialize(ChannelBuffer) - Static method in class org.apache.cassandra.transport.Event
-
- deserialize(int) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- deserialize(TDeserializer, TBase, DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Deprecated.
- deserialize(DataInput, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
Deserialize an IntervalTree whose keys use the natural ordering.
- deserialize(DataInput, int, Comparator<C>) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- deserialize(DataInput) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- deserializeBody(DataInput, ByteBuffer, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- deserializeBounds(DataInput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- deserializeCfId(DataInput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserializeColumnFamilies(Row) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize ColumnFamilies from low-level schema representation, all of them belong to the same keyspace
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- deserializeFromSSTable(DataInput, ColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Deserialize into the specified DataInputStream instance in the format
suited for SSTables.
- deserializeIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
Deserialize the index into a structure and return it
- deserializerSuperColumnFamily(DataInput, ColumnFamily, ColumnSerializer.Flag, int) - Static method in class org.apache.cassandra.db.SuperColumns
-
- destination - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- destroy() - Method in class org.apache.cassandra.service.CassandraDaemon
-
Clean up all resources obtained during the lifetime of the daemon.
- destroyConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- dfa1 - Variable in class org.apache.cassandra.cql.CqlLexer
-
- dfa1 - Variable in class org.apache.cassandra.cql.CqlParser
-
- dfa10 - Variable in class org.apache.cassandra.cql.CqlParser
-
- dfa103 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfa11 - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- dfa13 - Variable in class org.apache.cassandra.cql.CqlParser
-
- dfa14 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfa15 - Variable in class org.apache.cassandra.cql.CqlLexer
-
- dfa18 - Variable in class org.apache.cassandra.cli.CliLexer
-
- dfa19 - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- dfa2 - Variable in class org.apache.cassandra.cli.CliParser
-
- dfa2 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfa34 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfa43 - Variable in class org.apache.cassandra.cql.CqlParser
-
- dfa54 - Variable in class org.apache.cassandra.cql.CqlParser
-
- dfa6 - Variable in class org.apache.cassandra.cli.CliParser
-
- dfa7 - Variable in class org.apache.cassandra.cql.CqlLexer
-
- dfa76 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfa94 - Variable in class org.apache.cassandra.cql3.CqlParser
-
- dfile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- diff(Column) - Method in class org.apache.cassandra.db.Column
-
- diff(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
-
- diff(ColumnFamily, ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
-
- diff(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Determine the count relationship between two contexts.
- diff(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
-
Determine the relationship between two contexts.
- diff(Column) - Method in class org.apache.cassandra.db.CounterColumn
-
- diff(Column) - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- difference() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- difference(MerkleTree, MerkleTree) - Static method in class org.apache.cassandra.utils.MerkleTree
-
- Differencer - Class in org.apache.cassandra.repair
-
Runs on the node that initiated a request to compare two trees, and launch repairs for disagreeing ranges.
- Differencer(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.Differencer
-
- differences - Variable in class org.apache.cassandra.repair.Differencer
-
- differenceToFetch(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Calculate set of the difference ranges of given two ranges
(as current (A, B] and rhs is (C, D])
which node will need to fetch when moving to a given new token
- differencingDone - Variable in class org.apache.cassandra.repair.RepairSession
-
- digest(ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
-
- digest() - Method in class org.apache.cassandra.db.ReadResponse
-
- DIGEST - Static variable in class org.apache.cassandra.io.sstable.Component
-
- DigestMismatchException - Exception in org.apache.cassandra.service
-
- DigestMismatchException(DecoratedKey, ByteBuffer, ByteBuffer) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
-
- Digit - Static variable in class org.apache.cassandra.cli.CliLexer
-
- Digit - Static variable in class org.apache.cassandra.cli.CliParser
-
- DIGIT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- direction - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- direction - Variable in enum org.apache.cassandra.transport.Message.Type
-
- directories - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- Directories - Class in org.apache.cassandra.db
-
Encapsulate handling of paths to the data files.
- Directories.DataDirectory - Class in org.apache.cassandra.db
-
- Directories.DataDirectory(File) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
-
- Directories.SSTableLister - Class in org.apache.cassandra.db
-
- Directories.SSTableLister() - Constructor for class org.apache.cassandra.db.Directories.SSTableLister
-
- directory - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- disable() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- disable() - Method in class org.apache.cassandra.tools.Shuffle
-
Disable shuffling on all nodes in the cluster.
- disableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- disableAutoCompaction() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- disableAutoCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
-
- disableRelocations(String...) - Method in class org.apache.cassandra.tools.Shuffle
-
Disable relocations.
- disableRelocations(Collection<String>) - Method in class org.apache.cassandra.tools.Shuffle
-
Disable relocations.
- disableScheduledRangeXfers() - Method in class org.apache.cassandra.service.StorageService
-
- disableScheduledRangeXfers() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Disable processing of queued range transfers.
- discard(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Completely discards a segment file by deleting it.
- discardCompactionsInProgress() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- discardCompletedSegments(UUID, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Modifies the per-CF dirty cursors of any commit log segments for the column family according to the position
given.
- discardSSTables(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Discard all SSTables that were created before given timestamp.
- disconnect() - Static method in class org.apache.cassandra.cli.CliMain
-
Disconnect thrift connection to cassandra instance
- disk_access_mode - Variable in class org.apache.cassandra.config.Config
-
- disk_failure_policy - Variable in class org.apache.cassandra.config.Config
-
- DiskAwareRunnable - Class in org.apache.cassandra.io.util
-
- DiskAwareRunnable() - Constructor for class org.apache.cassandra.io.util.DiskAwareRunnable
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlLexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlParser
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlLexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
-
- doRetry(FileMessageHeader, Throwable) - Method in class org.apache.cassandra.streaming.StreamSession
-
- DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- DoubleSerializer - Class in org.apache.cassandra.serializers
-
- DoubleSerializer() - Constructor for class org.apache.cassandra.serializers.DoubleSerializer
-
- DoubleType - Class in org.apache.cassandra.db.marshal
-
- doVerb(MessageIn<CounterMutation>, int) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
-
- doVerb(MessageIn<Collection<RowMutation>>, int) - Method in class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.MigrationRequestVerbHandler
-
- doVerb(MessageIn<RowMutation>, int) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
-
- doVerb(MessageIn<ReadCommand>, int) - Method in class org.apache.cassandra.db.ReadVerbHandler
-
- doVerb(MessageIn<RowMutation>, int) - Method in class org.apache.cassandra.db.RowMutationVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- doVerb(MessageIn<Truncation>, int) - Method in class org.apache.cassandra.db.TruncateVerbHandler
-
- doVerb(MessageIn<GossipDigestAck2>, int) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- doVerb(MessageIn<GossipDigestAck>, int) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- doVerb(MessageIn<GossipDigestSyn>, int) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- doVerb(MessageIn<T>, int) - Method in interface org.apache.cassandra.net.IVerbHandler
-
This method delivers a message to the implementing class (if the implementing
class was registered by a call to MessagingService.registerVerbHandlers).
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.net.ResponseVerbHandler
-
- doVerb(MessageIn<RepairMessage>, int) - Method in class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- doVerb(MessageIn<EchoMessage>, int) - Method in class org.apache.cassandra.service.EchoVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.PrepareVerbHandler
-
- doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.ProposeVerbHandler
-
- doVerb(MessageIn<AbstractRangeCommand>, int) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
-
- doVerb(MessageIn<SnapshotCommand>, int) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
-
- doVerb(MessageIn, int) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
-
- drain() - Method in class org.apache.cassandra.service.StorageService
-
Shuts node off to writes, empties memtables and the commit log.
- drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
makes node unavailable for writes, flushes memtables and replays commitlog.
- drain(InputStream, long) - Method in class org.apache.cassandra.streaming.StreamReader
-
- drain() - Method in class org.apache.cassandra.tools.NodeProbe
-
- drop(String) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- drop(String) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of DROP USER query.
- drop(String) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- drop(String) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- DROP - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DROP - Static variable in class org.apache.cassandra.cli.CliParser
-
- dropCf(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- dropColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- dropFromSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
-
Remove all CF attributes from schema
- dropFromSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
-
- dropIndex() - Method in class org.apache.cassandra.cli.CliParser
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- DropIndexStatement - Class in org.apache.cassandra.cql
-
- DropIndexStatement(String) - Constructor for class org.apache.cassandra.cql.DropIndexStatement
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropIndexStatement - Class in org.apache.cassandra.cql3.statements
-
- DropIndexStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- DropKeyspaceStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- DROPPABLE_VERBS - Static variable in class org.apache.cassandra.net.MessagingService
-
Verbs it's okay to drop if the request has been queued longer than the request timeout.
- dropped - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
Number of dropped messages
- droppedColumns(Map<ByteBuffer, Long>) - Method in class org.apache.cassandra.config.CFMetaData
-
- DroppedMessageMetrics - Class in org.apache.cassandra.metrics
-
Metrics for dropped messages by verb.
- DroppedMessageMetrics(MessagingService.Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
-
- dropTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropTableStatement - Class in org.apache.cassandra.cql3.statements
-
- DropTableStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTableStatement
-
- dropTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- DropTriggerStatement(CFName, String) - Constructor for class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- dropUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropUserStatement - Class in org.apache.cassandra.cql3.statements
-
- DropUserStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.DropUserStatement
-
- dst - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- dumpInterArrivalTimes() - Method in class org.apache.cassandra.gms.FailureDetector
-
Dump the inter arrival times for examination if necessary.
- dumpInterArrivalTimes() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- duplicate() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- durableWrites - Variable in class org.apache.cassandra.config.KSMetaData
-
- dynamic_snitch - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_badness_threshold - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_reset_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- dynamic_snitch_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- DynamicCompositeType - Class in org.apache.cassandra.db.marshal
-
- DynamicEndpointSnitch - Class in org.apache.cassandra.locator
-
A dynamic snitch that sorts endpoints by latency with an adapted phi failure detector
- DynamicEndpointSnitch(IEndpointSnitch) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- DynamicEndpointSnitch(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- DynamicEndpointSnitchMBean - Interface in org.apache.cassandra.locator
-
- G - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- G - Static variable in class org.apache.cassandra.cql.CqlParser
-
- G - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- G - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- gatherTombstones(ColumnFamily, Iterator<? extends OnDiskAtom>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
Given an iterator of on disk atom, returns an iterator that filters the tombstone range
markers adding them to returnCF
and returns the normal column.
- GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- gcBefore(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- gcBefore - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- gcBefore - Variable in class org.apache.cassandra.repair.Validator
-
- gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- GCInspector - Class in org.apache.cassandra.service
-
- GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
-
- GE - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- generate() - Static method in class org.apache.cassandra.utils.CounterId
-
- generateCFMetadataUpdate() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- get(K) - Method in interface org.apache.cassandra.cache.ICache
-
- get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- get(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- GET - Static variable in class org.apache.cassandra.cli.CliLexer
-
- GET - Static variable in class org.apache.cassandra.cli.CliParser
-
- get(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CFDefinition
-
- get(int) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
- get() - Method in class org.apache.cassandra.cql3.Constants.Value
-
- get(String, List<? extends AssignementTestable>, ColumnSpecification) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- get() - Method in class org.apache.cassandra.cql3.Lists.Value
-
- get() - Method in class org.apache.cassandra.cql3.Maps.Value
-
- get() - Method in class org.apache.cassandra.cql3.Sets.Value
-
- get() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- get(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- get(String, String) - Static method in class org.apache.cassandra.locator.SnitchProperties
-
Get a snitch property value or return null if not defined.
- get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
-
- get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- get(String) - Method in class org.apache.cassandra.service.FileCacheService
-
- get() - Method in class org.apache.cassandra.service.ReadCallback
-
- get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- get(byte) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get() - Method in class org.apache.cassandra.tracing.Tracing
-
- get(UUID) - Method in class org.apache.cassandra.tracing.Tracing
-
- get(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- get(List<? extends Iterator<In>>, Comparator<In>, MergeIterator.Reducer<In, Out>) - Static method in class org.apache.cassandra.utils.MergeIterator
-
- get(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
For testing purposes.
- get(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
Returns true or false for the specified bit index.
- get(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- get(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true or false for the specified bit index.
- get(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true or false for the specified bit index.
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the current number of running tasks
- 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.CommitLogAllocator
-
- getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a milliseconds-since-epoch value for a type-1 UUID.
- getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAllDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
-
- getAllDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the list of all data file locations from conf
- getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
-
Get all ranges that span the ring given a set
of tokens.
- getAllSSTables() - Method in class org.apache.cassandra.db.Keyspace
-
- getAncestors() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds type information from @param bb to @param sb.
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getAndReferenceOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
like getOverlappingSSTables, but acquires references before returning
- getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
-
- getApplicationStateMap() - Method in class org.apache.cassandra.gms.EndpointState
-
Deprecated.
- getApproximateKeyCount(Iterable<SSTableReader>, CFMetaData) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
You should almost never use this.
- getArrayHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getArraySize(int, long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory an array will consume
- getArraySize(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte array consumes
- getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
-
- getAuthenticatedUser() - Method in interface org.apache.cassandra.auth.ISaslAwareAuthenticator.SaslAuthenticator
-
- getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthenticator() - Method in class org.apache.cassandra.transport.ServerConnection
-
- getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getBackingFiles() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
-
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getBaseComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getBatchlogMutationFor(Collection<RowMutation>, UUID) - Static method in class org.apache.cassandra.db.BatchlogManager
-
- getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
-
- getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- getBloomFilter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getBootstrapTokens(TokenMetadata, Map<InetAddress, Double>) - 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
-
- getBoundsTerms() - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Returns the number of bound terms in this statement.
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- getBoundsVariables() - 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
-
- 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
-
- getBufferSize() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getBuilder(Config.DiskAccessMode) - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of the names of the built column indexes for current store
- getBuiltIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getByte(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getByteBuffer(AbstractType<?>, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer according to a
comparator/validator.
- getByteBuffer() - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer.
- getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- 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
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCachePath(String, String, String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCaching() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCanonicalPath(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCanonicalPath(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getCasContentionTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCassandraServer() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getCF(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getCfDef() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCfDef(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the columnfamily definition for the signature
- getCfDef(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return the CfDef for the column family
- getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
-
Given a keyspace name & column family name, get the column family
meta data.
- getCFMetaData(UUID) - Method in class org.apache.cassandra.config.Schema
-
Get ColumnFamily metadata by its identifier
- getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
-
- getCFMetaData(String) - Method in class org.apache.cassandra.cql.AlterTableStatement
-
- getCFMetaData(String, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCFMetaData(String, String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Validate that keyspace
is an existing keyspace and cfName
one of its existing column family.
- getCfNamesByKeySpace(KsDef) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns set of column family names in specified keySpace.
- getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getChunksForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- 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
-
- 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
-
- 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
-
- getCollection(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getCollectionType() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
-
Get a column given its name, returning null if the column is not
present.
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getColumnComparator(AbstractType<?>) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getColumnComparator(AbstractType<?>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnComparator(AbstractType<?>) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnCount() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the number of columns in this map.
- getColumnCount() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns the ColumnDefinition for name
.
- getColumnDefinitionComparator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionForIndex(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionFromColumnName(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns a ColumnDefinition given a full (internal) column name.
- getColumnDefs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilies() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamily() - Method in class org.apache.cassandra.auth.DataResource
-
- getColumnFamily(Tree, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily(String, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column family namespace.
- getColumnFamily() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
-
- getColumnFamily(DecoratedKey, ByteBuffer, ByteBuffer, boolean, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
get a list of columns starting from a given column, in a specified order.
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
-
- getColumnFamily(UUID) - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given columnFamily
matching the Filter criteria in sorted order.
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnFamilyIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ReadCommand
-
- getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStore(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyType(String, String) - Method in class org.apache.cassandra.config.Schema
-
Get type of the ColumnFamily but it's keyspace/name
- getColumnFamilyWithColumns(ColumnFamily.Factory) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getColumnFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getColumnMeta(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get column meta data
- getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get a list of columns
- getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
get a list of column for the column family
- getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
include key columns
- getColumnName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column name to index.
- getColumnNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getColumnNames() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnNames() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnNames() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterable with the names of columns in this column map in the same order
as the underlying columns themselves.
- getColumnNames() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getColumnRelations() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnRelations() - Method in class org.apache.cassandra.cql.WhereClause
-
- getColumns() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumns() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnsList() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getColumnsString(Iterable<Column>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getColumnValues() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getCommandCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- getCommandDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- getComment() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the commit log
- getCommitLogPeriodicQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getCompactedRow(List<SSTableIdentityIterator>) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getCompactedRow(SSTableIdentityIterator) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
convenience method for single-sstable compactions
- getCompacting() - Method in class org.apache.cassandra.db.DataTracker
-
- getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- getCompactionInfo() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
-
- getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionOptions() - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- getCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactions() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction objects.
- getCompactions() - Static method in class org.apache.cassandra.metrics.CompactionMetrics
-
- getCompactionStrategy() - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- getCompactionStrategy() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionStrategyClass() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionStrategyClass() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the compaction strategy class name
- 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.
- getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getComparator(String, String) - Method in class org.apache.cassandra.config.Schema
-
Get column comparator for ColumnFamily but it's keyspace/name
- getComparator() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getComparator(String) - Method in class org.apache.cassandra.cql.SelectStatement
-
- getComparator(String) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getComparator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getComparator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- 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.db.TreeMapBackedSortedColumns
-
- getComparator(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- getComparatorFor(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- getComparatorFor(CFMetaData, boolean) - Static method in class org.apache.cassandra.db.SuperColumns
-
- getComparatorSerializedSize() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCompletedMesssages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getCompletedTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getComponent(int) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Returns the ith component added to this builder.
- getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- getComponentComparator(Integer, ColumnDefinition.Type) - Method in class org.apache.cassandra.config.CFMetaData
-
- getComponents() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Return a list of the "subcomponents" this type has.
- getComponents() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getCompressedBuilder() - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Returns the compression metadata for this sstable.
- getCompressionOptions() - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- getCompressionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the compression parameters
- getCompressionRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCompressor() - Method in class org.apache.cassandra.transport.Connection
-
- getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReplicators() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCondition() - Method in class org.apache.cassandra.cli.CliParser
-
- getConnection(InetAddress, MessageOut) - Method in class org.apache.cassandra.net.MessagingService
-
- getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.Attributes
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
Returns the consistency level of this UPDATE
statement, either
one parsed from the CQL statement, or the default level otherwise.
- getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getCoreCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of compaction thread pool
- getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Returns core pool size of thread pool.
- getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of validation thread pool
- getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCQL2KeyName() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLVersion() - Method in class org.apache.cassandra.service.ClientState
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
-
- getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return the generation value for this node.
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getCurrentLocalCounterId() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Read the current local node id from the system keyspace or null if no
such node id is recorded.
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCurrentlyBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- getCurrentPosition() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getCurrentState() - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- getCurrentStreams() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getCurrentStreams() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
Returns the current state of all ongoing streams.
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the current contents of the buffer.
- getData() - Method in interface org.apache.cassandra.service.IResponseResolver
-
returns the data response without comparing with any digests
- getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDigestResolver
-
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String representing the datacenter this endpoint belongs to
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the data center for the endpoint, or UNKNOWN
if not known.
- getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getDataTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Package protected for access from the CompactionManager.
- getDcLocalReadRepair() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultIndexName(String, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
construct a map to store the mashaller type to cassandra data type mapping
- getDefaultTimeToLive() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- getDirectories() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Get sstable directories for the CF.
- getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
-
- getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDouble(String, Double) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getDrainProgress() - Method in class org.apache.cassandra.service.StorageService
-
- getDrainProgress() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the progress of a drain operation
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.DataTracker
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
Get the amount of droppable tombstones
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getDroppedColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts for server lifetime
- getDroppedMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getDroppedMessages() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEndpoint(Range<Token>) - Method in class org.apache.cassandra.client.RingCache
-
ListMultimap promises to return a List for get(K)
- getEndpoint(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getEndpointForHostId(UUID) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the end-point for a unique host ID
- getEndpointInfo(InetAddress) - 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
-
- 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
-
- 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
-
- getEntity() - Method in class org.apache.cassandra.cql.Relation
-
- getEntity() - Method in class org.apache.cassandra.cql3.Relation
-
- getEntryIterator(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.Memtable
-
- getEpSnitchProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
-
- getEstimatedAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getExceptionCount() - Method in class org.apache.cassandra.service.StorageService
-
- getExceptionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Calculate expected file size of SSTable after compaction.
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getExpectedWriteSize() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Get expected write size to determine which disk to use for this task.
- getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- getExtraFilter(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
Returns a filter to query the columns from the clause that the initial slice filter may not have caught.
- getExtraFilter(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- getFactory() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the factory used for this ISortedColumns implementation.
- getFactory() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getFactory() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
-
Get system file descriptor from FileDescriptor object.
- getFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a class consumes, including the object header and the size of the fields.
- getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getFilter(long, int, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFilter(long, double, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFinish() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getFirstEmptyKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFlushQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFullColumnFamily() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- getFullyExpiredSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getFullyExpiredSSTables(ColumnFamilyStore, Set<SSTableReader>, Set<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
Finds expired sstables
works something like this;
1.
- getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the full class name
- getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
- getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
-
- getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getGrammarFileName() - Method in class org.apache.cassandra.cli.CliLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cli.CliParser
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlParser
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getHeapMemoryUsage() - 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
-
- getHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of endpoint to host ID
- getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getId(String, String) - Method in class org.apache.cassandra.config.Schema
-
Lookup keyspace/ColumnFamily identifier
- getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getId() - Method in class org.apache.cassandra.repair.RepairSession
-
- getId() - Method in enum org.apache.cassandra.transport.DataType
-
- getId() - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- getIdentityFilter(DecoratedKey, String, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
return a QueryFilter object that includes every column in the row.
- getIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Allow access to the underlying column family store if there is one
- getIndexComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the index comparator for index backed by CFS, or null.
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexes() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get a list of columns with defined index
- getIndexesBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesByNames(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesNotBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
-
- getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Deprecated.
- getIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getIndexKeyFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the decoratedKey for a column value
- getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Index name (or null).
- getIndexName() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns IndexOperator from string representation
- getIndexOperator(Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
get the position in the index file to start scanning to find the given key (at most indexInterval keys away)
- getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexType(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get index type from string
- getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInitialTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInMemoryCompactionLimit() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
may be null if unset
- getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- 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
-
- getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(AbstractType...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(AbstractType<T>) - 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>) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
-
- getInstance(TypeSerializer<K>, TypeSerializer<V>) - Static method in class org.apache.cassandra.serializers.MapSerializer
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.SetSerializer
-
- getInt(String, Integer) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInt(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getInternodeAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInValues() - Method in class org.apache.cassandra.cql3.Relation
-
- getIOWait() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getIterator(Iterable<Memtable>, Collection<SSTableReader>, DataRange, ColumnFamilyStore, long) - Static method in class org.apache.cassandra.db.RowIteratorFactory
-
Get a row iterator over the provided memtables and sstables, between the provided keys
and filtered by the queryfilter.
- getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently bootstrapping into the ring.
- getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKey(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getKey() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.WhereClause
-
- getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
-
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyComponent(int) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getKeys() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.WhereClause
-
- getKeySample(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySampleSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySet() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getKeysMeta(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get keys meta data
- getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
-
- getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
-
- getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeyspace() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyspace() - Method in class org.apache.cassandra.cql3.CFName
-
- getKeyspace() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getKeyspace() - Method in class org.apache.cassandra.db.ReadCommand
-
- getKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getKeyspace() - Method in interface org.apache.cassandra.service.IReadCommand
-
- getKeySpaceDef(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliUtils
-
Parse the statement from cli and return KsDef
- getKeyspaceDefinitions() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Get keyspace instance by name
- getKeyspaceMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace inner ColumnFamilies
- getKeyspaceName() - Method in class org.apache.cassandra.db.CounterMutation
-
- getKeyspaceName() - Method in interface org.apache.cassandra.db.IMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.db.RowMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKeyStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyType() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getKeyType(String) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getKSMetaData(String) - Method in class org.apache.cassandra.cli.CliClient
-
- getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace by its name
- getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
caller should not modify leavingEndpoints
- getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently leaving the ring.
- getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the length of the valid data currently in the buffer.
- getLengthInBytes() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- getLevel(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelCount() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelSorted(int, Comparator<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLifetimeReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.DataRange
-
- getLiveCount(ColumnFamily, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getLiveCount(IDiskAtomFilter, long) - Method in class org.apache.cassandra.db.Row
-
- getLiveDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLiveNaturalEndpoints(Keyspace, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
This method attempts to return N endpoints that are responsible for storing the
specified key i.e for replication.
- getLiveNaturalEndpoints(Keyspace, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of live nodes in the cluster, where "liveness" is
determined by the failure detector of the node being queried.
- getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLiveNodes() - Method in class org.apache.cassandra.tools.Shuffle
-
Return a list of the live nodes (using JMX).
- getLiveSize() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Get current amount of memory this index is consuming (in bytes)
- getLiveSize() - Method in class org.apache.cassandra.db.Memtable
-
- getLiveSortedEndpoints(Keyspace, ByteBuffer) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLoad() - Method in class org.apache.cassandra.service.StorageService
-
raw load value
- getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- getLoadMap() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value.
- getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLoadString() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value
- getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
Please use getBroadcastAddress instead.
- getLocalComparator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.DeletedColumn
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getLocalDeletionTime() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
-
- getLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Read the host ID from the system keyspace, creating (and storing) one if
none exists.
- getLocalHostId() - Method in class org.apache.cassandra.service.StorageService
-
- getLocalHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve this hosts unique ID
- getLocalHostId() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalId() - Static method in class org.apache.cassandra.utils.CounterId
-
- getLocalPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getLocationForDisk(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories
-
Returns SSTable location which is inside given data directory.
- getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getLong(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getMap(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.DeletedColumn
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getMaxCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMaxDataAge(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getMaxHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaxHintsThread() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- 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
- getMaximumSize() - Method in class org.apache.cassandra.utils.Allocator
-
- getMaximumSize() - Method in class org.apache.cassandra.utils.HeapAllocator
-
- getMaximumSize() - Method in class org.apache.cassandra.utils.SlabAllocator
-
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Returns maximum pool size of thread pool.
- 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
- getMaxLiveCount() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaxStreamingRetries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanColumns() - Method in class org.apache.cassandra.db.DataTracker
-
- getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
- getMemtableAllocator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableColumnIterator(Memtable) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getMemtableColumnsCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableColumnsCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableFlushPeriod() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.DataTracker
-
- getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
-
- getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception message.
- getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
-
- getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getMessageType() - Method in class org.apache.cassandra.net.MessageIn
-
- getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- getMetadata() - Method in interface org.apache.cassandra.io.util.ICompressedFile
-
- getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMinimalKey(DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
as large as necessary.
- getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the minimum number of sstables in queue before compaction kicks off
- getMinimumSize() - Method in class org.apache.cassandra.utils.Allocator
-
- getMinimumSize() - Method in class org.apache.cassandra.utils.HeapAllocator
-
- getMinimumSize() - Method in class org.apache.cassandra.utils.SlabAllocator
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getMinRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Endpoints which are migrating to the new tokens
- getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently moving in the ring.
- getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.BatchStatement
-
- getMutations(List<ByteBuffer>, boolean, ConsistencyLevel, long, boolean) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
Convert statement into a list of mutations to apply on the server
- getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getName() - Method in class org.apache.cassandra.auth.DataResource
-
- getName() - Method in interface org.apache.cassandra.auth.IResource
-
- getName() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Name of the column family to create
- getName() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getName() - Method in class org.apache.cassandra.db.Keyspace
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Return the unique name for this index and column
to be stored in the SystemKeyspace that tracks if each column is built
- getNamesFilter(DecoratedKey, String, SortedSet<ByteBuffer>, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getNamesFilter(DecoratedKey, String, ByteBuffer, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
convenience method for creating a name filter matching a single column
- getNativeTransportAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
get the (possibly cached) endpoints that should store the given Token.
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.LocalStrategy
-
We need to override this even if we override calculateNaturalEndpoints,
because the default implementation depends on token calculations but
LocalStrategy may be used before tokens are set up.
- getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
- getNaturalEndpoints(String, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNeighbors(String, Range<Token>, boolean) - Static method in class org.apache.cassandra.service.ActiveRepairService
-
Return all of the neighbors with whom we share the provided range.
- getNewInOrderSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNewSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
get next row
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- 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
-
- getNextId() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
-
- getNextWide() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
read wide row
- getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getNormalizedLoadAvg() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Expert: gets the number of longs in the array that are in use
- getObjectHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getObjectPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getoffHeapMemoryAllocator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOldLocalCounterIds() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getOldLocalCounterIds() - Static method in class org.apache.cassandra.utils.CounterId
-
Return the list of old local counter id of this node.
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Return the current file pointer of the underlying on-disk file.
- getOnDiskIterator(DataInput, int, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskIterator(DataInput, int, ColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getOpeningString() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.Bounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.Range
-
- getOperationMode() - Method in class org.apache.cassandra.service.StorageService
-
- getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the operational mode (leaving, joining, normal, decommissioned, client)
- getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getOperations() - Method in class org.apache.cassandra.db.Memtable
-
- getOperations() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getOptions() - Method in class org.apache.cassandra.cql3.UserOptions
-
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
The original number of columns requested by the user.
- getOutboundBindAny() - Static method in class org.apache.cassandra.config.Config
-
- getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
The OutputCommitter for this format does not write any data to the DFS.
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionParamaters(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
output format
- getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getOwnership() - Method in class org.apache.cassandra.service.StorageService
-
- getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
given a list of tokens (representing the nodes in the cluster), returns
a mapping from "token -> %age of cluster owned by that token"
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageSize() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The pageSize for this query.
- getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The paging state for this query, or null if not relevant.
- getParent() - Method in class org.apache.cassandra.auth.DataResource
-
- getParent() - Method in interface org.apache.cassandra.auth.IResource
-
Gets next resource in the hierarchy.
- getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
-
- getPartitioner() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPartitioner(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
-
Return a partitioner instance for remote host.
- getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitionerName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the cluster partitioner
- getPartitionerName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the cluster partitioner
- getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return partition keys
- getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getPathInfo() - Method in interface org.apache.cassandra.cache.CacheKey
-
- getPathInfo() - Method in class org.apache.cassandra.cache.KeyCacheKey
-
- getPathInfo() - Method in class org.apache.cassandra.cache.RowCacheKey
-
- getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
a mutable map may be returned but caller should not modify it
- getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of pending ranges to endpoints that describe the ring topology
- getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPigType(AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get pig type for the cassandra data type
- getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Get position updating key cache and stats.
- getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- getPosition() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
- getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPreferredIP(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getPrefetchedList(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- getPreheatKeyCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPrepared(MD5Digest) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrepared(Integer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrepared() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getPrimaryRangeForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- 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.
- getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- getProcessor(CassandraServer) - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getProperty(String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyBoolean(String, Boolean) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyDouble(String, Double) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyInt(String, Integer) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertySet(String, Set<String>) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyString(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getProtectedConstructor(Class, Class...) - Static method in class org.apache.cassandra.utils.Hex
-
Used to get access to protected/private constructor of the specified class
- getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Used to get access to protected/private field of the specified class
- getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
decompose the query to store the parameters in a map
- getQueryState() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String repesenting the rack this endpoint belongs to
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the rack for the endpoint, or UNKNOWN
if not known.
- getRack() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRandomToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
-
- getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getRange() - Method in class org.apache.cassandra.repair.RepairSession
-
- getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractRangeCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- 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() - Static method in class org.apache.cassandra.streaming.StreamManager
-
Gets streaming rate limiter.
- getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getRawText() - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getReadExecutor(ReadCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
-
- getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getReadRepairAttempted() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairAttempted() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairAttempted() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBackground() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBlocking() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReceivedCount() - Method in class org.apache.cassandra.service.ReadCallback
-
- getReceivingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getReceivingStream(UUID) - Method in class org.apache.cassandra.streaming.StreamManager
-
- getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentHitRate() - Method in class org.apache.cassandra.metrics.CacheMetrics
-
Deprecated.
- getRecentLatency() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- getRecentLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getRecentLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
returns microseconds
- getRecentlyDropped() - Method in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
Deprecated.
- getRecentlyDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentlyDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts since last called
- getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentTimeout() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getRecentTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check per host.
- getRecentTotalTimeout() - Static method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTotalTimouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTotalTimouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check.
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlLexer
-
- getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlParser
-
- getRecognitionErrors() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- getRecognitionErrors() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Get the RecordWriter
for the given task.
- getReduced() - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- getReferenceSize() - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- getReferenceSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRelation(Bound, Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the Cassandra version.
- getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getRelocatingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Ranges which are migrating to new endpoints.
- getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- 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
-
- getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplayPosition(Iterable<? extends SSTableReader>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
Convenience method to compute the replay position for a group of SSTables.
- getReplayPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getReplicateOnWrite() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.KSPropDefs
-
- getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
-
- getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.KSPropDefs
-
- getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
-
- getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getReturnType(String, String, String) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Deprecated.
use reverseComparator field instead
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getRow(QueryFilter) - Method in class org.apache.cassandra.db.Keyspace
-
- getRow(Keyspace) - Method in class org.apache.cassandra.db.ReadCommand
-
- getRow(Keyspace) - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- getRow(Keyspace) - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- getRowCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcaddress(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Return the rpc address associated with an endpoint as a string.
- getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the saved caches dir
- getSavedTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getScanner(DataRange) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
I/O SSTableScanner
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Returns a list of KeyScanners given sstables and a range on which to scan.
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getSchedulingValue() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getSchema(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
define the schema
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
schema: (value, value, value) where keys are in the front.
- getSchemaKSKey(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getSchemaVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getSchemaVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the current Schema version.
- getSchemaVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
-
- getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Returns each live node's schema version
- getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
-
- getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- getSendingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Serial consistency for conditional updates.
- getSerializedCachePath(String, String, CacheService.CacheType, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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.ColumnToCollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LongType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.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
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getShortName(AbstractType<?>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- getSimple(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- getSimple(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getSize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte buffer consumes
- getSliceFilter(DecoratedKey, String, ByteBuffer, ByteBuffer, boolean, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDirectory(Descriptor, String) - Static 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.
- getSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getSortedColumns() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- 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
- getSpecifications() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- getSpeculativeRetry() - Method in class org.apache.cassandra.config.CFMetaData
-
- getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- getSplits(JobConf, int) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- getSplits(String, String, Range<Token>, int, CFMetaData) - Method in class org.apache.cassandra.service.StorageService
-
- getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
Get an iterator that returns columns from the given SSTable using the opened file
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given SSTable
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTableCountPerLevel() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTables() - Method in class org.apache.cassandra.db.DataTracker
-
- getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesForKey(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSstablesIterated() - Method in class org.apache.cassandra.db.CollationController
-
- getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
-
Retrieve a stage from the StageManager
- getStage() - Method in class org.apache.cassandra.net.MessageOut
-
- getStart() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- getStatements() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStrategyClass() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getStrategyOptions() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getStreamId() - Method in class org.apache.cassandra.transport.Message
-
- getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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.PropertyDefinitions
-
- getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.Column
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.CounterColumn
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a string representation of the bytes suitable for log messages
- getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getSummary() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getSuperclassFieldPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getSuperClassFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a super class consumes, given the primitive field sizes
- getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTempSSTablePath(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getText() - Method in class org.apache.cassandra.cql.Term
-
Returns the text parsed to create this term.
- getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getThriftClient(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
-
Setup and return a new Thrift RPC connection.
- getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getThriftFramedTransportSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getTimeout(MessagingService.Verb) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTimeout() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- getTimeout() - Method in class org.apache.cassandra.db.ReadCommand
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageIn
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageOut
-
- getTimeout() - Method in interface org.apache.cassandra.service.IReadCommand
-
- getTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts per host
- getTimestamp(ThriftClientState) - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimestamp() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimestamp(long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimestamp(long, List<ByteBuffer>) - 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.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
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getTimeToLive(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimeToLive(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimeToLive() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- 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.
- getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a 16 byte representation of a type 1 UUID (a time-based UUID),
based on the current system time.
- getTimeUUIDBytes(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a milliseconds-since-epoch timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a 100-nanoseconds precision timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getToken() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getToken() - Method in class org.apache.cassandra.db.RowPosition
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
Generate the token of a key.
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToken() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getToken() - Method in class org.apache.cassandra.dht.Token
-
- getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthChallenge
-
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthSuccess
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenNames() - Method in class org.apache.cassandra.cli.CliParser
-
- getTokenNames() - Method in class org.apache.cassandra.cql.CqlParser
-
- getTokenNames() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getTokens(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getTokens(String) - Method in class org.apache.cassandra.service.StorageService
-
- getTokens() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for this node.
- getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for a specified node.
- getTokens() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of tokens to endpoints, including the bootstrapping
ones.
- getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getTopLevelColumns() - Method in class org.apache.cassandra.db.CollationController
-
- getTopLevelColumns(QueryFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTopLevelDeletion() - Method in class org.apache.cassandra.db.DeletionInfo
-
- getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTotalBatchesReplayed() - Method in class org.apache.cassandra.db.BatchlogManager
-
- getTotalBatchesReplayed() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
- getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getTotalBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks that had blocked before being accepted (or
rejected).
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
- getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalBytesCompacted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCommitlogSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getTotalCommitlogSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCompactionsCompleted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTotalLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getTotalLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getTotalLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
returns microseconds
- getTotalLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getTotalMemtableLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalMemtableSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- 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
-
- getTotalSizeReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Total number of timeouts happened on this node
- getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
-
- getTracingProbability() - Method in class org.apache.cassandra.service.StorageService
-
- getTracingProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the configured tracing probability.
- getTracker() - Method in class org.apache.cassandra.transport.Connection
-
- getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.FramedTransportFactory
-
- getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.SSLTransportFactory
-
- getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.addColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.addKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.arrayConstruct_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.assumeStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attr_name_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueDouble_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueInt_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueString_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.command_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.comparator_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.connectStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.countStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.describeCluster_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.describeTable_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.dropIndex_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.entityName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.exitStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.functionArgument_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.functionCall_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.getCondition_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.getStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.hashConstruct_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.hashElementPair_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.helpStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.host_name_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.host_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.incrementValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.incrStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.ip_address_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePair_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.listStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.newColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.operator_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.password_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.port_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.reversedExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.root_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowKey_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.setStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.setTraceProbability_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showClusterName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showKeyspaces_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showSchema_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showVersion_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.statement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.traceNextQuery_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.traceSessionId_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.tracingProbability_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.truncateStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.typeIdentifier_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.updateKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.useKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.username_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.value_return
-
- getTreeAdaptor() - Method in class org.apache.cassandra.cli.CliParser
-
- getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTriggers() - Method in class org.apache.cassandra.config.CFMetaData
-
- getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- 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
-
- getTruncationRecords() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncationTime() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getType() - Method in class org.apache.cassandra.cql.Term
-
Obtain the term's type.
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- getType() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- getType() - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- getType() - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ListSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.LongSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.MapSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.SetSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- getType() - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
-
Get AbstractType by function name
- getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.DataTracker
-
- getUncompactingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- getUnfinishedCompactions() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getUnleveledSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUnleveledSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- 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
-
- getUnreadableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
-
- getUnreadableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
-
- getUnsignedShort(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CollectionType
-
- getUnsignedShort(ByteBuffer) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- getUnwritableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
-
- getUnwritableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getUpdateTimestamp() - Method in class org.apache.cassandra.gms.EndpointState
-
- getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getUser() - Method in class org.apache.cassandra.service.ClientState
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getUsername() - Method in class org.apache.cassandra.cli.CliClient
-
- 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 enum org.apache.cassandra.cli.CliClient.Function
-
- getValidator() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getValidator() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the validators
- getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- getValue() - Method in class org.apache.cassandra.cql.Relation
-
- getValue() - Method in class org.apache.cassandra.cql3.Relation
-
- getValue() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getValueValidator(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
- getValueValidator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- getValueValidator(String, String, ByteBuffer) - Method in class org.apache.cassandra.config.Schema
-
Get value validator for specific column
- getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.SelectStatement
-
- getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getVerbHandler(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
This method returns the verb handler associated with the registered
verb.
- getVersion() - Method in class org.apache.cassandra.config.Schema
-
- getVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
- GetVersion - Class in org.apache.cassandra.tools
-
- GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
-
- getVersion() - Method in class org.apache.cassandra.transport.Connection
-
- getView() - Method in class org.apache.cassandra.db.DataTracker
-
- getWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getWorkMap(Multimap<Range<Token>, InetAddress>) - Static method in class org.apache.cassandra.dht.RangeStreamer
-
- getWriteableLocation() - Method in class org.apache.cassandra.db.Directories
-
- getWriteableLocationAsFile() - Method in class org.apache.cassandra.db.Directories
-
- getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
retained for benefit of old tests
- getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getWriter() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- GLOBAL_OPTIONS - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- GossipDigest - Class in org.apache.cassandra.gms
-
Contains information about a specified list of Endpoints and the largest version
of the state they have generated as known by the local endpoint.
- GossipDigestAck - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestSynMessage by an
endpoint.
- GossipDigestAck2 - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestAckMessage.
- GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- GossipDigestSyn - Class in org.apache.cassandra.gms
-
This is the first message that gets sent out as a start of the Gossip protocol in a
round.
- GossipDigestSyn(String, String, List<GossipDigest>) - Constructor for class org.apache.cassandra.gms.GossipDigestSyn
-
- GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- Gossiper - Class in org.apache.cassandra.gms
-
This module is responsible for Gossiping information for the local endpoint.
- GossiperMBean - Interface in org.apache.cassandra.gms
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
called after Gossiper instance exists immediately before it starts gossiping
- gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Called in preparation for the initiation of the gossip loop.
- GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
-
- GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
-
- GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Grants a set of permissions on a resource to a user.
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- grantStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- GrantStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.GrantStatement
-
- GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
-
- groups() - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- GuidGenerator - Class in org.apache.cassandra.utils
-
- GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
-
- guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- I - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- I - Static variable in class org.apache.cassandra.cql.CqlParser
-
- I - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- I - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IAllocator - Interface in org.apache.cassandra.io.util
-
- IAsyncCallback<T> - Interface in org.apache.cassandra.net
-
implementors of IAsyncCallback need to make sure that any public methods
are threadsafe with respect to response() being called from the message
service.
- IAuthenticator - Interface in org.apache.cassandra.auth
-
- IAuthenticator.Option - Enum in org.apache.cassandra.auth
-
Supported CREATE USER/ALTER USER options.
- IAuthorizer - Interface in org.apache.cassandra.auth
-
Primary Cassandra authorization interface.
- IBitSet - Interface in org.apache.cassandra.utils.obs
-
- ICache<K,V> - Interface in org.apache.cassandra.cache
-
This is similar to the Map interface, but requires maintaining a given capacity
and does not require put or remove to return values, which lets SerializingCache
be more efficient by avoiding deserialize except on get.
- IColumnIteratorFactory - Interface in org.apache.cassandra.db.columniterator
-
- ICommitLogExecutorService - Interface in org.apache.cassandra.db.commitlog
-
Like ExecutorService, but customized for batch and periodic commitlog execution.
- ICompactionScanner - Interface in org.apache.cassandra.db.compaction
-
An ICompactionScanner is an abstraction allowing multiple SSTableScanners to be
chained together under the hood.
- ICompressedFile - Interface in org.apache.cassandra.io.util
-
- ICompressor - Interface in org.apache.cassandra.io.compress
-
- ICompressor.WrappedArray - Class in org.apache.cassandra.io.compress
-
A simple wrapper of a byte array.
- ICompressor.WrappedArray(byte[]) - Constructor for class org.apache.cassandra.io.compress.ICompressor.WrappedArray
-
- IContext - Interface in org.apache.cassandra.db.context
-
An opaque commutative context.
- IContext.ContextRelationship - Enum in org.apache.cassandra.db.context
-
- id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- id - Variable in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- id() - Method in class org.apache.cassandra.db.ColumnFamily
-
- id - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- id - Variable in exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
-
- id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- id - Variable in class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- IDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- IDENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- Identifier - Static variable in class org.apache.cassandra.cli.CliLexer
-
- Identifier - Static variable in class org.apache.cassandra.cli.CliParser
-
- IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
-
- IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
-
Will read entire CF into memory.
- IDiskAtomFilter - Interface in org.apache.cassandra.db.filter
-
Given an implementation-specific description of what columns to look for, provides methods
to extract the desired columns from a Memtable, SSTable, or SuperColumn.
- IDiskAtomFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- IDiskAtomFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- IDLE_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
-
- IEndpointLifecycleSubscriber - Interface in org.apache.cassandra.service
-
Interface on which interested parties can be notified of high level endpoint
state changes.
- IEndpointSnitch - Interface in org.apache.cassandra.locator
-
This interface helps determine location of node in the data center relative to another node.
- IEndpointStateChangeSubscriber - Interface in org.apache.cassandra.gms
-
This is called by an instance of the IEndpointStateChangePublisher to notify
interested parties about changes in the the state associated with any endpoint.
- IExecutorMBean - Interface in org.apache.cassandra.concurrent
-
Deprecated.
- IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
-
Implemented by the Gossiper to convict an endpoint
based on the PHI calculated by the Failure Detector on the inter-arrival
times of the heart beats.
- IFailureDetector - Interface in org.apache.cassandra.gms
-
An interface that provides an application with the ability
to query liveness information of a node in the cluster.
- IFailureNotification - Interface in org.apache.cassandra.gms
-
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- ifile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- IFilter - Interface in org.apache.cassandra.utils
-
- ignored - Variable in class org.apache.cassandra.db.filter.ColumnCounter
-
- ignored() - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- ignoredSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- IInternodeAuthenticator - Interface in org.apache.cassandra.auth
-
- ILatencySubscriber - Interface in org.apache.cassandra.locator
-
- IMeasurableMemory - Interface in org.apache.cassandra.cache
-
- IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
-
- IMessageSink - Interface in org.apache.cassandra.net.sink
-
- IMigrationListener - Interface in org.apache.cassandra.service
-
- importJson(String, String, String, String) - Method in class org.apache.cassandra.tools.SSTableImport
-
Convert a JSON formatted file to an SSTable.
- IMutation - Interface in org.apache.cassandra.db
-
- in - Variable in class org.apache.cassandra.cli.CliSessionState
-
- in_memory_compaction_limit_in_mb - Variable in class org.apache.cassandra.config.Config
-
- includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- includes(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- includeStartKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- IncludingExcludingBounds<T extends RingPosition> - 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
-
- incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- IncomingStreamingConnection - Class in org.apache.cassandra.net
-
Thread to consume stream init messages.
- IncomingStreamingConnection(int, Socket) - Constructor for class org.apache.cassandra.net.IncomingStreamingConnection
-
- IncomingTcpConnection - Class in org.apache.cassandra.net
-
- IncomingTcpConnection(int, boolean, Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
-
- INCR - Static variable in class org.apache.cassandra.cli.CliLexer
-
- INCR - Static variable in class org.apache.cassandra.cli.CliParser
-
- incrCompactionSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- incrCreatedHints(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- incremental_backups - Variable in class org.apache.cassandra.config.Config
-
- incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- incrementDroppedMessages(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- incrementValue() - Method in class org.apache.cassandra.cli.CliParser
-
- incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- incrStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- INDEX - Static variable in class org.apache.cassandra.cli.CliLexer
-
- INDEX - Static variable in class org.apache.cassandra.cli.CliParser
-
- index(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
Index the given row.
- INDEX_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- index_interval - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- indexCfs - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- indexColumnFamilyName(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
generate a column family name for an index corresponding to the given column.
- indexComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- indexedEntryEnd() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryNameBuilder - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryStart() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexEntry - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns true if the provided column name is indexed by this secondary index.
- indexes(ByteBuffer, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- indexFor(ByteBuffer, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType<?>, boolean, int) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
The index of the IndexInfo in which a scan starting with @name should begin.
- IndexHelper - Class in org.apache.cassandra.io.sstable
-
Provides helper to serialize, deserialize and use column indexes.
- IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
-
- IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
-
- IndexHelper.IndexInfo(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- indexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- indexName - Variable in class org.apache.cassandra.cql.DropIndexStatement
-
- indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- indexReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- indexRow(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
When building an index against existing data, add the given row to the index
- indexRow(DecoratedKey, ColumnFamilyStore, Set<String>) - Static method in class org.apache.cassandra.db.Keyspace
-
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- IndexSummary - Class in org.apache.cassandra.io.sstable
-
- IndexSummary(IPartitioner, Memory, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
-
- IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
-
- IndexSummary.IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder(long, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- indexValue - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- InetAddressSerializer - Class in org.apache.cassandra.serializers
-
- InetAddressSerializer() - Constructor for class org.apache.cassandra.serializers.InetAddressSerializer
-
- InetAddressType - Class in org.apache.cassandra.db.marshal
-
- inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
-
- init() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- init() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Perform any initialization work
- init(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Initialize the client.
- init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize the Cassandra Daemon based on the given
Commons
Daemon-specific arguments.
- init(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
-
Bind this session to report to specific
StreamResultFuture
and
perform pre-streaming initialization.
- init() - Method in class org.apache.cassandra.utils.MerkleTree
-
Initializes this tree by splitting it until hashdepth is reached,
or until an additional level of splits would violate maxsize.
- initCf(UUID, String, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
adds a cf to internal structures, ends up creating disk files).
- initClient() - Method in class org.apache.cassandra.service.StorageService
-
- initClient(int) - Method in class org.apache.cassandra.service.StorageService
-
- initial_token - Variable in class org.apache.cassandra.config.Config
-
- initialComparator - Variable in class org.apache.cassandra.db.Memtable
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- initialCompressedBufferLength(int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- initializeFromMessage(MessageIn<?>) - Method in class org.apache.cassandra.tracing.Tracing
-
Determines the tracing context from a message.
- initializeNodeUnsafe(InetAddress, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
-
- initiate() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up incoming message handler and initiate streaming.
- initiateOnReceivingSide(Socket, 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
-
- initLog4j() - Static method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize logging in such a way that it checks for config changes every 10 seconds.
- initReceivingSide(UUID, String, InetAddress, Socket, boolean, int) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
-
- initRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
Methods to get the column family schema from Cassandra
- initServer() - Method in class org.apache.cassandra.service.StorageService
-
- initServer(int) - Method in class org.apache.cassandra.service.StorageService
-
- injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- inOrderDeletionTester() - Method in class org.apache.cassandra.db.ColumnFamily
-
- inOrderTester(boolean) - Method in class org.apache.cassandra.db.DeletionInfo
-
- INotification - Interface in org.apache.cassandra.notifications
-
Created by IntelliJ IDEA.
- INotificationConsumer - Interface in org.apache.cassandra.notifications
-
- inProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- inputVersion - Variable in class org.apache.cassandra.streaming.StreamReader
-
- insert(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- insert(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
insert a column to the index
- insert(Column) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when constructing the index against pre-existing data
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- insertStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- insertStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- insertUser(String, boolean) - Static method in class org.apache.cassandra.auth.Auth
-
Inserts the user into AUTH_KS.USERS_CF (or overwrites their superuser status as a result of an ALTER USER query).
- instance - Static variable in class org.apache.cassandra.config.Schema
-
- instance - Static variable in class org.apache.cassandra.db.BatchlogManager
-
- instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- instance - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- instance() - Static method in class org.apache.cassandra.db.context.CounterContext
-
- instance - Static variable in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
- instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BooleanType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DateType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LongType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
-
- instance - Static variable in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- instance - Static variable in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- instance - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- instance - Static variable in class org.apache.cassandra.gms.Gossiper
-
- instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
-
- instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
-
- instance() - Static method in class org.apache.cassandra.net.MessagingService
-
- instance - Static variable in class org.apache.cassandra.serializers.AsciiSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BytesSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- instance - Static variable in class org.apache.cassandra.service.CacheService
-
- instance - Static variable in class org.apache.cassandra.service.FileCacheService
-
- instance - Static variable in class org.apache.cassandra.service.GCInspector
-
- instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- instance - Static variable in class org.apache.cassandra.service.StorageProxy
-
- instance - Static variable in class org.apache.cassandra.service.StorageService
-
- instance - Static variable in class org.apache.cassandra.streaming.StreamManager
-
- instance - Static variable in class org.apache.cassandra.thrift.ThriftSessionManager
-
- instance - Static variable in class org.apache.cassandra.tracing.Tracing
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- instance - Static variable in class org.apache.cassandra.triggers.TriggerExecutor
-
- instance - Static variable in class org.apache.cassandra.utils.HeapAllocator
-
- InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
-
Wraps an ICache in requests + hits tracking.
- InstrumentingCache(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
-
- Int32Serializer - Class in org.apache.cassandra.serializers
-
- Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
-
- Int32Type - Class in org.apache.cassandra.db.marshal
-
- INTEGER - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql.CqlParser
-
- integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- IntegerSerializer - Class in org.apache.cassandra.serializers
-
- IntegerSerializer() - Constructor for class org.apache.cassandra.serializers.IntegerSerializer
-
- IntegerType - Class in org.apache.cassandra.db.marshal
-
- inter_dc_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
-
- internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- internedNames - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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
-
- internOrCopy(ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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.
- 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(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- intersects(List<ByteBuffer>, List<ByteBuffer>, SliceQueryFilter) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- intersects(List<ByteBuffer>, List<ByteBuffer>, SliceQueryFilter) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
return true if @param range intersects any of the given @param ranges
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
-
- intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- Interval<C,D> - Class in org.apache.cassandra.utils
-
- Interval(C, C, D) - Constructor for class org.apache.cassandra.utils.Interval
-
- intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
-
- intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
-
- IntervalTree<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- IntervalTree(Collection<I>, Comparator<C>) - Constructor for class org.apache.cassandra.utils.IntervalTree
-
- IntervalTree.Serializer<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- intTerm() - Method in class org.apache.cassandra.cql.CqlParser
-
- intValue() - Method in class org.apache.cassandra.cql3.CqlParser
-
- invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
call when dropping or renaming a CF.
- invalidate() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Remove the index and unregisters this index's mbean if one exists
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Remove the index
- invalidate(String) - Method in class org.apache.cassandra.service.FileCacheService
-
- invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Invalidates the ranges containing the given token.
- invalidateCachedRow(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- invalidateCachedTokenEndpointValues() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- invalidateCaches() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- 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
-
- InvalidRequestException - Exception in org.apache.cassandra.exceptions
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
-
- invalids() - Method in class org.apache.cassandra.utils.MerkleTree
-
Returns a lazy iterator of invalid TreeRanges that need to be filled
in order to make the given Range valid.
- invalidSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- inverse() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- IOWAIT_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliParser
-
- ip_address() - Method in class org.apache.cassandra.cli.CliParser
-
- IPartitioner<T extends Token> - Interface in org.apache.cassandra.dht
-
- IReadCommand - Interface in org.apache.cassandra.service
-
- IRequestScheduler - Interface in org.apache.cassandra.scheduler
-
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
- IResource - Interface in org.apache.cassandra.auth
-
The interface at the core of Cassandra authorization.
- IResponseResolver<TMessage,TResolved> - Interface in org.apache.cassandra.service
-
- IRowCacheEntry - Interface in org.apache.cassandra.cache
-
- IRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- isActive - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
pause/resume/getNextBackgroundTask must synchronize.
- isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
-
- isAlive() - Method in class org.apache.cassandra.gms.EndpointState
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Failure Detector's knowledge of whether a node is up or
down.
- isAlive - Static variable in interface org.apache.cassandra.net.IAsyncCallback
-
- isAlwaysEmpty(AbstractType<?>, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
If IAuthenticator doesn't require authentication, this method may return true.
- ISaslAwareAuthenticator - Interface in org.apache.cassandra.auth
-
- ISaslAwareAuthenticator.SaslAuthenticator - Interface in org.apache.cassandra.auth
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- isAssignableTo(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignementTestable
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
-
- isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAutoCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isAutoCompactionDisabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAvailable() - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- isAvailable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isBefore(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isBindMarker() - Method in class org.apache.cassandra.cql.Term
-
- isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
-
- IsBootstrappingException - Exception in org.apache.cassandra.exceptions
-
- IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
-
- isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- isClean() - Method in class org.apache.cassandra.db.Memtable
-
- isCleanerAvailable() - Static method in class org.apache.cassandra.io.util.FileUtils
-
- isClientMode() - Static method in class org.apache.cassandra.config.Config
-
- isClientMode() - Method in class org.apache.cassandra.service.StorageService
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCollection() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isColumnFamilyLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isColumnList() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCompact - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- isCompatibleWith(Operation.RawUpdate) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- isCompatibleWith(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.ColumnToCollectionType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- isComplete() - Method in interface org.apache.cassandra.auth.ISaslAwareAuthenticator.SaslAuthenticator
-
- isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
-
- isComposite - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- isConnected() - Static method in class org.apache.cassandra.cli.CliMain
-
Checks whether the thrift client is connected.
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCounter() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCounter() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCounter() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isCountOperation() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isDataPresent() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RowDataResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RowDigestResolver
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
-
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.DeletionInfo
-
Return whether a given column is deleted by the container having this
deletion info.
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.DeletionInfo
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.DeletionTime
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
-
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- isDeleted(ByteBuffer, long) - 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.
- isDelta() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
-
- isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
-
- isDirty - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UserOptions
-
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns true if this contains no columns or deletion info
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- isEmpty() - Method in class org.apache.cassandra.db.RowMutation
-
- 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.ExpiringMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.IntervalTree
-
- isEmpty() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true if there are no set bits
- isEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
-
- isEncryptedChannel(InetAddress) - Static method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isEQ() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- ISerializer<T> - Interface in org.apache.cassandra.io
-
- isExhausted() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- isExhausted() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Whether or not this pager is exhausted, i.e.
- isExistingUser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the username is stored in AUTH_KS.USERS_CF.
- isExpired() - Method in class org.apache.cassandra.db.Memtable
-
- isFailed() - Method in class org.apache.cassandra.repair.RepairJob
-
- isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isFatClient(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isFullRowSlice(SliceQueryFilter) - Static method in class org.apache.cassandra.db.DataRange
-
- isFullWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- isGcAble(int) - Method in class org.apache.cassandra.db.DeletionTime
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isIN() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- 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
-
- isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
true if this CFS contains secondary index data
- isIndexBuilt(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Checks if the index for specified column is fully built
- isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isIndexed() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- isIndexEntryStale(ByteBuffer, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- isIndexing(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- isIndexNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isInitialized() - Method in class org.apache.cassandra.service.StorageService
-
- isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns if this map only support inserts in reverse order.
- isInsertReversed() - Method in class org.apache.cassandra.db.EmptyColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- 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
-
- isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
-
- isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isLive(long) - Method in class org.apache.cassandra.db.Column
-
- isLive() - Method in class org.apache.cassandra.db.DeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- isLive(Column, DeletionInfo.InOrderTester, long) - Static method in class org.apache.cassandra.db.filter.ColumnCounter
-
- isLocalId() - Method in class org.apache.cassandra.utils.CounterId
-
- isLocalTask() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
Returns true if the task if the task can be executed locally, false if
it has to be forwarded.
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.Column
-
- isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
-
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.DeletedColumn
-
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in class org.apache.cassandra.db.RowPosition
-
- isMinimum(IPartitioner) - Method in interface org.apache.cassandra.dht.RingPosition
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- isMinimum() - Method in class org.apache.cassandra.dht.Token
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- isMinimumBound - Variable in class org.apache.cassandra.dht.Token.KeyBound
-
- isModified() - Method in class org.apache.cassandra.utils.DefaultDouble
-
- isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMultiKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isMultiKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- isMultithreadedCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- iso8601Patterns - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isOnToken() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Checks whether the socket is connected.
- isOutgoingConnected() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- isPaging - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
-
- isPresent(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
-
- isPure() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- isPure() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
-
- isRelocating(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isReversed() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Returns whether the server is currently running.
- isRunning() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- isRunning() - Method in class org.apache.cassandra.transport.Server
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, ColumnNameBuilder) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, ColumnNameBuilder) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- isSequential - Variable in class org.apache.cassandra.repair.RepairSession
-
- isSerialConsistency() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
True if an explicit consistency level was parsed from the statement.
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
True if an explicit consistency level was parsed from the statement.
- isSetKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isSetTimestamp() - Method in class org.apache.cassandra.cql.AbstractModification
-
- isSetTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
-
- isShutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- isSignaled() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isSlice() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- ISSTableSerializer<T> - Interface in org.apache.cassandra.io
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- 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
-
- isSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Checks the user's superuser status.
- isSuper() - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperuser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the user is a known superuser.
- isSupportedBy(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- isThriftCompatible() - Method in class org.apache.cassandra.config.CFMetaData
-
Returns whether this CFMetaData can be returned to thrift.
- isThriftCompatible() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isTimeToLiveSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
-
Indicates if the current thread's execution is being traced.
- isTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- isUnary() - Method in class org.apache.cassandra.cql.Operation
-
- isUnix() - Static method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- isUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for reads.
- isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for writes.
- isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- isWildcard() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
Returns whether for a range query doing a query against merged is likely
to be faster than 2 sequential queries, one against l1 followed by one against l2.
- isWrapAround() - Method in class org.apache.cassandra.db.DataRange
-
- isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
-
Tells if the given range is a wrap around.
- isWrapAround() - Method in class org.apache.cassandra.dht.Range
-
- isWritetime - Variable in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- iterator() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- iterator() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- iterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterator over the columns of this map that returns only the matching @param slices.
- iterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- iterator() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- iterator() - Method in class org.apache.cassandra.db.compaction.ParallelCompactionIterable
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.EmptyColumns
-
- iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- iterator() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- iterator - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- iterator(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- iterator() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- iterator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
- iterators() - Method in interface org.apache.cassandra.utils.IMergeIterator
-
- iterators - Variable in class org.apache.cassandra.utils.MergeIterator
-
- iterators() - Method in class org.apache.cassandra.utils.MergeIterator
-
- ITransportFactory - Interface in org.apache.cassandra.thrift
-
Transport factory for establishing thrift connections from clients to a remote server.
- ITrigger - Interface in org.apache.cassandra.triggers
-
- IVerbHandler<T> - Interface in org.apache.cassandra.net
-
IVerbHandler provides the method that all verb handlers need to implement.
- IVersionedSerializer<T> - Interface in org.apache.cassandra.io
-
- M - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- M - Static variable in class org.apache.cassandra.cql.CqlParser
-
- M - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- M - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- mA() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mA() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- main(String[]) - Static method in class org.apache.cassandra.cli.CliMain
-
- main(String[]) - Static method in class org.apache.cassandra.gms.FailureDetector
-
- main(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- main(String[]) - Static method in class org.apache.cassandra.tools.BulkLoader
-
- main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
-
- main(String[]) - Static method in class org.apache.cassandra.tools.NodeCmd
-
- main(String[]) - Static method in class org.apache.cassandra.tools.Shuffle
-
Execute.
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
-
Given arguments specifying an SSTable, and optionally an output file,
export the contents of the SSTable to JSON.
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableImport
-
Converts JSON to an SSTable file.
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableLevelResetter
-
- main(String[]) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneScrubber
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneSplitter
-
- main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneUpgrader
-
- main(String[]) - Static method in class org.apache.cassandra.transport.Client
-
- major - Variable in class org.apache.cassandra.utils.SemanticVersion
-
- makeArgSpec(ColumnSpecification, Function, int) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- makeColumn(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeCountResult(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ResultSet
-
- makeCountResult(String, String, long, ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.ResultSet
-
- makeExtendedFilter(AbstractBounds<RowPosition>, SliceQueryFilter, ByteBuffer, ByteBuffer, List<IndexExpression>, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Allows generic range paging with the slice column filter.
- makeExtendedFilter(AbstractBounds<RowPosition>, IDiskAtomFilter, List<IndexExpression>, int, boolean, boolean, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- makeFilename(File, String, String) - Static method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- makeIndexColumnName(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- makeIndexColumnName(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- makeIndexColumnName(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- makeIndexColumnNameBuilder(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- makeIndexColumnNameBuilder(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- makeIndexColumnNameBuilder(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- makeIndexColumnNameBuilder(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- makeMutation() - Method in class org.apache.cassandra.service.paxos.Commit
-
- makeMutationMessage() - Method in class org.apache.cassandra.db.CounterMutation
-
- makeRangeTombstone(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeReplicationMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- makeRowBounds(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Bounds
-
Compute a bounds of keys corresponding to a given bounds of token.
- makeRowRange(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Range
-
Compute a range of keys corresponding to a given range of token.
- makeSnapshots(Collection<InetAddress>) - Method in class org.apache.cassandra.repair.RepairJob
-
- makeToBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- makeTombstone(ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeTombstoneForOverwrite(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- malloc(long) - Method in interface org.apache.cassandra.io.util.JEMallocAllocator.JEMLibrary
-
- mAlnum() - Method in class org.apache.cassandra.cli.CliLexer
-
- manages(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
- mAND() - Method in class org.apache.cassandra.cli.CliLexer
-
- manifestNeedsMigration(String, String) - Static method in class org.apache.cassandra.db.compaction.LegacyLeveledManifest
-
Deprecated.
We need to migrate if there is a legacy leveledmanifest json-file
If there is no jsonfile, we can just start as normally, sstable level will be at 0 for all sstables.
- map(CQL3Type, CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- map - Variable in class org.apache.cassandra.cql3.Maps.Value
-
- map_literal() - Method in class org.apache.cassandra.cql3.CqlParser
-
- mAPI_VERSION() - Method in class org.apache.cassandra.cli.CliLexer
-
- MappedFileDataInput - Class in org.apache.cassandra.io.util
-
- MappedFileDataInput(FileInputStream, String, long, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
-
- MappedFileDataInput(MappedByteBuffer, String, long, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
-
- MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- Maps - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for maps.
- Maps.DelayedValue - Class in org.apache.cassandra.cql3
-
- Maps.DelayedValue(Comparator<ByteBuffer>, Map<Term, Term>) - Constructor for class org.apache.cassandra.cql3.Maps.DelayedValue
-
- Maps.DiscarderByKey - Class in org.apache.cassandra.cql3
-
- Maps.DiscarderByKey(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.DiscarderByKey
-
- Maps.Literal - Class in org.apache.cassandra.cql3
-
- Maps.Literal(List<Pair<Term.Raw, Term.Raw>>) - Constructor for class org.apache.cassandra.cql3.Maps.Literal
-
- Maps.Marker - Class in org.apache.cassandra.cql3
-
- Maps.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
-
- Maps.Putter - Class in org.apache.cassandra.cql3
-
- Maps.Putter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Putter
-
- Maps.Setter - Class in org.apache.cassandra.cql3
-
- Maps.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
-
- Maps.SetterByKey - Class in org.apache.cassandra.cql3
-
- Maps.SetterByKey(ColumnIdentifier, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
-
- Maps.Value - Class in org.apache.cassandra.cql3
-
- Maps.Value(Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
-
- MapSerializer<K,V> - Class in org.apache.cassandra.serializers
-
- MapType<K,V> - Class in org.apache.cassandra.db.marshal
-
- mark() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- mark() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- mark - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The current mark position.
- mark(int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Sets a mark position in this ByteArrayInputStream.
- mark() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- mark(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- mark() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- mark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- mark() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- mark() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- markAllCompacting() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markClean(UUID, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Marks the ColumnFamily specified by cfId as clean for this log segment.
- markCompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- markCurrentSSTablesReferenced() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Get the current sstables, acquiring references on all of them.
- markDeltaToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Mark context to delete delta afterward.
- markDeltaToBeCleared() - Method in class org.apache.cassandra.db.CounterColumn
-
- markedForDeleteAt - Variable in class org.apache.cassandra.db.DeletionTime
-
- markedPointer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
-
- markObsolete() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Mark the sstable as obsolete, i.e., compacted into newer sstables.
- markReferenced(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markReferenced(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markReferenced(Collection<AbstractBounds<RowPosition>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- markSupported() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Indicates whether this stream supports the mark()
and
reset()
methods.
- markSupported() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- markSupported() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- markSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- MarshalException - Exception in org.apache.cassandra.serializers
-
- MarshalException(String) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- mASSUME() - Method in class org.apache.cassandra.cli.CliLexer
-
- max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- max - Variable in class org.apache.cassandra.utils.Interval
-
- max() - Method in class org.apache.cassandra.utils.IntervalTree
-
- MAX_CACHE_PREPARED - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- MAX_COLUMNS_DEFAULT - Static variable in class org.apache.cassandra.cql.SelectExpression
-
- max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- max_hints_delivery_threads - Variable in class org.apache.cassandra.config.Config
-
- MAX_NAME_LENGTH - Static variable in class org.apache.cassandra.db.Column
-
- MAX_REPLICATE_ON_WRITE_TASKS - Static variable in class org.apache.cassandra.concurrent.StageManager
-
- MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- max_streaming_retries - Variable in class org.apache.cassandra.config.Config
-
- MAX_TTL - Static variable in class org.apache.cassandra.db.ExpiringColumn
-
- MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- maxColumnNames - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
- maxColumnNames - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- maxColumnNames - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- maxColumns() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- maxCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- maxComponents(List<ByteBuffer>, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
-
finds the max column name(s)
if comparator is of CompositeType, candidate will be split into its components, and each
component is compared to the component on the same place in maxSeen, and then returning the list
with the max columns.
- maxDataAge - Variable in class org.apache.cassandra.io.sstable.SSTableReader
-
maxDataAge is a timestamp in local server time (e.g.
- MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- maxKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- maxKeyBound() - Method in class org.apache.cassandra.dht.Token
-
- maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
- maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- maxMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- maxRemaining() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- maxRemaining() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
The maximum number of cells/CQL3 row that we may still have to return.
- maxResults - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- maxRows() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- maxRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Size of the largest compacted row
- maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
-
- maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
-
- maxTimestamp() - Method in class org.apache.cassandra.db.Column
-
- maxTimestamp() - Method in class org.apache.cassandra.db.ColumnFamily
-
- maxTimestamp() - Method in class org.apache.cassandra.db.DeletionInfo
-
The maximum timestamp mentioned by this DeletionInfo.
- maxTimestamp() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- maxTimestamp() - Method in class org.apache.cassandra.db.RangeTombstone
-
- maxTimestamp - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
- maxTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- maxTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- maxTimestampComparator - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- maxTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns the biggest possible type 1 UUID having the provided timestamp.
- maxTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- maybeAddEntry(DecoratedKey, 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
- maybeArchive(String, String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- maybeBuildSecondaryIndexes(Collection<SSTableReader>, Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Does a full, blocking rebuild of the indexes specified by columns from the sstables.
- maybeCorrectResource(DataResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- maybeEscapeName(String) - Static method in class org.apache.cassandra.cli.CliUtils
-
- maybeGenerateRetryCommand(RowDataResolver, Row) - Method in class org.apache.cassandra.db.ReadCommand
-
- maybeGenerateRetryCommand(RowDataResolver, Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- maybeIncrementallyBackup(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
-
- maybeInitializeLocalState(int) - Method in class org.apache.cassandra.gms.Gossiper
-
- maybeIntern(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- maybeLoad() - Static method in class org.apache.cassandra.utils.Mx4jTool
-
Starts a JMX over http interface if and mx4j-tools.jar is in the classpath.
- maybeMarkUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Adds parent directory of the file (or the file itself, if it is a directory)
to the set of unreadable directories.
- maybeMarkUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Adds parent directory of the file (or the file itself, if it is a directory)
to the set of unwritable directories.
- maybeRenew(CounterColumn) - Method in class org.apache.cassandra.utils.CounterId.OneShotRenewer
-
- maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.ColumnFamily
-
- maybeResolveForRepair() - Method in class org.apache.cassandra.service.ReadCallback
-
Check digests in the background on the Repair stage if we've received replies
too all the requests we sent.
- maybeRestoreArchive() - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- maybeTrim(Row) - Method in class org.apache.cassandra.db.ReadCommand
-
- maybeTrim(Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- maybeUpdateRowCache(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- mayNeedPaging(Pageable, int) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
- maySelectPrefix(Comparator<ByteBuffer>, ByteBuffer) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- maySelectPrefix(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- maySelectPrefix(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- mB() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mB() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.db.BlacklistedDirectories
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.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.StorageProxy
-
- MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- mBOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mBY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mC() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mCharacterEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOLUMN() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mCOMPIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mCONFIG() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCONNECT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCONSISTENCYLEVEL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOUNT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCREATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mD() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MD5Digest - Class in org.apache.cassandra.utils
-
The result of the computation of an MD5 digest.
- mDecimalDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDECR() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDEL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDESCRIBE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDIGIT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mDIGIT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mDoubleLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDROP() - Method in class org.apache.cassandra.cli.CliLexer
-
- mE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mean() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- meanRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Size of the smallest compacted row
- measureDeep(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- Memory - Class in org.apache.cassandra.io.util
-
An off-heap region of memory that must be manually free'd when no longer needed.
- Memory(long) - Constructor for class org.apache.cassandra.io.util.Memory
-
- memory_allocator - Variable in class org.apache.cassandra.config.Config
-
- MemoryInputStream - Class in org.apache.cassandra.io.util
-
- MemoryInputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
-
- MemoryOutputStream - Class in org.apache.cassandra.io.util
-
This class provides a way to stream the writes into the
Memory
- MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
-
- memorySize() - Method in interface org.apache.cassandra.cache.IMeasurableMemory
-
- memorySize() - Method in class org.apache.cassandra.cache.KeyCacheKey
-
- memorySize() - Method in class org.apache.cassandra.cache.RowCacheKey
-
- memorySize() - Method in class org.apache.cassandra.cache.RowCacheSentinel
-
- memorySize() - Method in class org.apache.cassandra.db.ColumnFamily
-
- memorySize() - Method in class org.apache.cassandra.db.DeletionTime
-
- memorySize() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- memorySize() - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- Memtable - Class in org.apache.cassandra.db
-
- Memtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
-
- memtable_allocator - Variable in class org.apache.cassandra.config.Config
-
- memtable_flush_queue_size - Variable in class org.apache.cassandra.config.Config
-
- memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
-
- memtable_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- memtableColumnsCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Total number of columns present in the memtable.
- memtableDataSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Total amount of data stored in the memtable, including column related overhead.
- memtableFlushPeriod(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- memtables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- memtableSwitchCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Number of times flush has resulted in the memtable being switched out.
- merge(ColumnFamily, List<CloseableIterator<Column>>, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- merge(ByteBuffer, ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
-
Return a context w/ an aggregated count for each counter id.
- merge(ByteBuffer, ByteBuffer, Allocator) - Method in interface org.apache.cassandra.db.context.IContext
-
Return a context w/ an aggregated count for each node id.
- merge(StreamingHistogram) - Method in class org.apache.cassandra.utils.StreamingHistogram
-
Merges given histogram with this histogram.
- mergeAndRemoveOldShards(DecoratedKey, ColumnFamily, int, int) - Static method in class org.apache.cassandra.db.CounterColumn
-
- mergeAndRemoveOldShards(DecoratedKey, ColumnFamily, int, int, boolean) - Static method in class org.apache.cassandra.db.CounterColumn
-
There is two phase to the removal of old shards.
- mergeCounters - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- MergeIterator<In,Out> - Class in org.apache.cassandra.utils
-
Merges sorted input iterators which individually contain unique items.
- MergeIterator(List<? extends Iterator<In>>, MergeIterator.Reducer<In, Out>) - Constructor for class org.apache.cassandra.utils.MergeIterator
-
- MergeIterator.Candidate<In> - Class in org.apache.cassandra.utils
-
- MergeIterator.Candidate(Iterator<In>, Comparator<In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
-
- MergeIterator.Reducer<In,Out> - Class in org.apache.cassandra.utils
-
Accumulator that collects values of type A, and outputs a value of type B.
- MergeIterator.Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
-
- mergeMax(List<ByteBuffer>, List<ByteBuffer>, AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
-
if columnNameComparator is CompositeType the columns are compared by components using the subcomparator
on the same position.
- mergeMin(List<ByteBuffer>, List<ByteBuffer>, AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
-
if columnNameComparator is CompositeType the columns are compared by components using the subcomparator
on the same position.
- mergeSchema(Collection<RowMutation>) - Static method in class org.apache.cassandra.db.DefsTables
-
Merge remote schema in form of row mutations with local and mutate ks/cf metadata objects
(which also involves fs operations on add/drop ks/cf)
- mergeShardBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- mergeTombstoneHistogram(StreamingHistogram) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- 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.MerkleTreeSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- MerkleTree.RowHash - Class in org.apache.cassandra.utils
-
Hash value representing a row, to be used to pass hashes to the MerkleTree.
- MerkleTree.RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
-
- MerkleTree.TreeDifference - Class in org.apache.cassandra.utils
-
- MerkleTree.TreeDifference(Token, Token, byte) - Constructor for class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- 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.
- mEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- Message - Class in org.apache.cassandra.transport
-
A message from the CQL binary protocol.
- Message(Message.Type) - Constructor for class org.apache.cassandra.transport.Message
-
- Message.Codec<M extends Message> - Interface in org.apache.cassandra.transport
-
- Message.Direction - Enum in org.apache.cassandra.transport
-
- Message.Dispatcher - Class in org.apache.cassandra.transport
-
- Message.Dispatcher() - Constructor for class org.apache.cassandra.transport.Message.Dispatcher
-
- Message.ProtocolDecoder - Class in org.apache.cassandra.transport
-
- Message.ProtocolDecoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolDecoder
-
- Message.ProtocolEncoder - Class in org.apache.cassandra.transport
-
- Message.ProtocolEncoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolEncoder
-
- Message.Request - Class in org.apache.cassandra.transport
-
- Message.Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
-
- Message.Response - Class in org.apache.cassandra.transport
-
- Message.Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
-
- Message.Type - Enum in org.apache.cassandra.transport
-
- MessageDeliveryTask - Class in org.apache.cassandra.net
-
- MessageDeliveryTask(MessageIn, int, long) - 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
-
- messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.cassandra.transport.Message.Dispatcher
-
- messageType - Variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- MessagingService - Class in org.apache.cassandra.net
-
- MessagingService.Verb - Enum in org.apache.cassandra.net
-
- MessagingServiceMBean - Interface in org.apache.cassandra.net
-
MBean exposing MessagingService metrics.
- metadata - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- metadata - Variable in class org.apache.cassandra.cql3.ResultSet
-
- metadata - Variable in class org.apache.cassandra.cql3.UpdateParameters
-
- metadata - Variable in class org.apache.cassandra.db.ColumnFamily
-
- metadata() - Method in class org.apache.cassandra.db.ColumnFamily
-
- metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- metadata - Variable in class org.apache.cassandra.db.Keyspace
-
- metadata - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- metadata - Variable in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- metadata - Variable in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- MeteredFlusher - Class in org.apache.cassandra.db
-
- MeteredFlusher() - Constructor for class org.apache.cassandra.db.MeteredFlusher
-
- metric - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- MetricNameFactory - Interface in org.apache.cassandra.metrics
-
- metrics - Variable in class org.apache.cassandra.db.HintedHandOffManager
-
- mEXIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mEXPONENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mF() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mF() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mFAMILY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mFILE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mFLOAT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mFLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mG() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mG() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mGET() - Method in class org.apache.cassandra.cli.CliLexer
-
- mH() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mHELP() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHEX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mHEX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mHexDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHexEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHEXNUMBER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mI() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mI() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- microsTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- mIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mIDENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mIdentifier() - Method in class org.apache.cassandra.cli.CliLexer
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate a Token representing the approximate "middle" of the given
range.
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Given two bit arrays represented as BigIntegers, containing the given
number of significant bits, calculate a midpoint.
- migrateManifests(String, String) - Static method in class org.apache.cassandra.db.compaction.LegacyLeveledManifest
-
Deprecated.
- MIGRATION_DELAY_IN_MS - Static variable in class org.apache.cassandra.service.MigrationManager
-
- MigrationManager - Class in org.apache.cassandra.service
-
- MigrationManager.MigrationsSerializer - Class in org.apache.cassandra.service
-
- MigrationManager.MigrationsSerializer() - Constructor for class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- MigrationRequestVerbHandler - Class in org.apache.cassandra.db
-
Sends it's current schema state in form of row mutations in reply to the remote node's request.
- MigrationRequestVerbHandler() - Constructor for class org.apache.cassandra.db.MigrationRequestVerbHandler
-
- min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- min - Variable in class org.apache.cassandra.utils.Interval
-
- min() - Method in class org.apache.cassandra.utils.IntervalTree
-
- MIN_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- minColumnNames - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
max and min column names according to comparator
- minColumnNames - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- minColumnNames - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- minCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- minComponents(List<ByteBuffer>, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
-
finds the min column name(s)
if comparator is of CompositeType, candidate will be split into its components, and each
component is compared to the component on the same place in minSeen, and then returning the list
with the min columns.
- mINCR() - Method in class org.apache.cassandra.cli.CliLexer
-
- mINDEX() - Method in class org.apache.cassandra.cli.CliLexer
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- minKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- minKeyBound() - Method in class org.apache.cassandra.dht.Token
-
- minMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- minor - Variable in class org.apache.cassandra.utils.SemanticVersion
-
- minRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Size of the smallest compacted row
- minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- mINTEGER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mINTEGER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mIntegerNegativeLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mIntegerPositiveLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- minTimestamp() - Method in class org.apache.cassandra.db.Column
-
- minTimestamp() - Method in class org.apache.cassandra.db.DeletionInfo
-
- minTimestamp() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
For a standard column, this is the same as timestamp().
- minTimestamp() - Method in class org.apache.cassandra.db.RangeTombstone
-
- minTimestamp - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
the largest (client-supplied) timestamp in the row
- minTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- minTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- minTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns the smaller possible type 1 UUID having the provided timestamp.
- minTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- minValue(Class<R>) - Method in class org.apache.cassandra.dht.AbstractPartitioner
-
- minValue(Class<R>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- mIP_ADDRESS() - Method in class org.apache.cassandra.cli.CliLexer
-
- mJ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mJ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ADD() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_ADD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALLOW() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALTER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_ALTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_AND() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_AND() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_APPLY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_APPLY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_AS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ASC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ASCII() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_AUTHORIZE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BATCH() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_BATCH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BEGIN() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_BEGIN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BIGINT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BLOB() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CLUSTERING() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COMPACT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CONSISTENCY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_COUNT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_COUNT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COUNTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CREATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_CREATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CUSTOM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DECIMAL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DELETE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_DELETE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DESC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DISTINCT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DOUBLE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DROP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_DROP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_EXISTS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FILTERING() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FIRST() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_FLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FROM() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_FROM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_GRANT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_IF() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_IN() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_IN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INDEX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INDEX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INET() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INSERT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INSERT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INTO() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INTO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_KEY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEYSPACE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_KEYSPACE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEYSPACES() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_LEVEL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_LIMIT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_LIMIT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_LIST() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_MAP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_MODIFY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_NORECURSIVE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_NOSUPERUSER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_NOT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_NULL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_OF() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ON() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_ON() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ORDER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PASSWORD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PERMISSION() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PERMISSIONS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PRIMARY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_PRIMARY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_RENAME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_REVERSED() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_REVOKE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SELECT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_SELECT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SET() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_SET() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_STORAGE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SUPERUSER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TEXT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TIMESTAMP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TIMESTAMP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TIMEUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TOKEN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TRIGGER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TRUNCATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TRUNCATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TTL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TTL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TYPE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TYPE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UNLOGGED() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UPDATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_UPDATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_USE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USERS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USING() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_USING() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VALUES() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_VALUES() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VARCHAR() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VARINT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WHERE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_WHERE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WITH() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_WITH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WRITETIME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mKEYSPACE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mKEYSPACES() - Method in class org.apache.cassandra.cli.CliLexer
-
- mL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mLetter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mLETTER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mLETTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mLIMIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mLIST() - Method in class org.apache.cassandra.cli.CliLexer
-
- mM() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MmappedSegmentedFile - Class in org.apache.cassandra.io.util
-
- MmappedSegmentedFile(String, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mN() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mNEXT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mNonEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mO() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- ModificationStatement - Class in org.apache.cassandra.cql3.statements
-
- ModificationStatement(int, CFMetaData, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
-
- ModificationStatement.Parsed - Class in org.apache.cassandra.cql3.statements
-
- ModificationStatement.Parsed(CFName, Attributes.Raw, List<Pair<ColumnIdentifier, Operation.RawUpdate>>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- mON() - Method in class org.apache.cassandra.cli.CliLexer
-
- mostInterestingBucket(List<List<SSTableReader>>, int, int) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- mostRecentInProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- mostRecentInProgressCommitWithUpdate - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- move(String) - Method in class org.apache.cassandra.service.StorageService
-
- move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- move(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- movedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
-
- moveToNext() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- moving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- mP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mPROBABILITY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mQ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mQMARK() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mQMARK() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mQUERY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQUIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQUOTED_NAME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mR() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mR() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mRANGEOP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mS() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mSCHEMA() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSEMICOLON() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSET() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSHOW() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSingleEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSingleStringCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- mSTRING_LITERAL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mSTRING_LITERAL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mStringLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__100() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__101() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__102() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__103() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__104() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__105() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__106() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__107() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__111() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__112() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__113() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__114() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__115() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__116() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__117() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__118() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__119() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__120() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__121() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__122() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__123() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__124() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__125() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__126() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__127() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__128() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__129() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__130() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__131() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__132() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__133() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__134() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__135() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__136() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__137() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__138() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__139() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__140() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__141() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__142() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__143() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__144() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__145() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__146() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__147() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__148() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__149() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__150() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__81() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__82() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__83() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__84() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__85() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__86() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__87() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__88() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__89() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__90() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__91() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__92() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__93() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__94() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__95() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__96() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__97() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__98() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__99() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mTokens() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTokens() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mTokens() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mTRACE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTRUNCATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTTL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mU() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mU() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- 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
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- multithreaded_compaction - Variable in class org.apache.cassandra.config.Config
-
- mUnicodeEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mUPDATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- Murmur3BloomFilter - Class in org.apache.cassandra.utils
-
- Murmur3BloomFilter(int, IBitSet) - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter
-
- Murmur3BloomFilter.Murmur3BloomFilterSerializer - Class in org.apache.cassandra.utils
-
- Murmur3BloomFilter.Murmur3BloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
-
- Murmur3Partitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using a Murmur3 hash.
- Murmur3Partitioner() - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner
-
- MurmurHash - Class in org.apache.cassandra.utils
-
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
- MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
-
- mUSE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mutate(Collection<? extends IMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied
across all replicas.
- mutateAtomically(Collection<RowMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
See mutate.
- mutateCounter(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
-
Handle counter mutation on the coordinator host.
- mutateLevel(Pair<SSTableMetadata, Set<Integer>>, Descriptor, String, int) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
Scary method mutating existing sstable component
Tries to do it safely by moving the new file on top of the old one
Caller needs to reload the sstable metadata (sstableReader.reloadSSTableMetadata())
- mutateWithTriggers(Collection<? extends IMutation>, ConsistencyLevel, boolean) - Static method in class org.apache.cassandra.service.StorageProxy
-
- mutationForKey(ByteBuffer, String, Long, ThriftClientState, List<ByteBuffer>, CFMetaData) - Method in class org.apache.cassandra.cql.DeleteStatement
-
- mUUID() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mV() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mV() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mW() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mW() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mWITH() - Method in class org.apache.cassandra.cli.CliLexer
-
- mWS() - Method in class org.apache.cassandra.cli.CliLexer
-
- mWS() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mWS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- Mx4jTool - Class in org.apache.cassandra.utils
-
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
- Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
-
- mY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mZ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mZ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- P - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- P - Static variable in class org.apache.cassandra.cql.CqlParser
-
- P - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- P - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- pack(List<ByteBuffer>, int, int) - Static method in class org.apache.cassandra.db.marshal.CollectionType
-
- pack(List<ByteBuffer>, int) - Static method in class org.apache.cassandra.db.marshal.CollectionType
-
- pack(List<ByteBuffer>, int, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- pack(List<ByteBuffer>, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- Pageable - Interface in org.apache.cassandra.service.pager
-
Marker interface for commands that can be paged.
- Pageable.ReadCommands - Class in org.apache.cassandra.service.pager
-
- Pageable.ReadCommands(List<ReadCommand>) - Constructor for class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- PagedRangeCommand - Class in org.apache.cassandra.db
-
- PagedRangeCommand(String, String, long, AbstractBounds<RowPosition>, SliceQueryFilter, ByteBuffer, ByteBuffer, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.PagedRangeCommand
-
- pager(Pageable, ConsistencyLevel) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
- pager(Pageable, ConsistencyLevel, PagingState) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
- pageRowLocally(ColumnFamilyStore, ByteBuffer, int) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
Convenience method to (locally) page an internal row.
- pagingState - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- PagingState - Class in org.apache.cassandra.service.pager
-
- PagingState(ByteBuffer, ByteBuffer, int) - Constructor for class org.apache.cassandra.service.pager.PagingState
-
- PAIR - Static variable in class org.apache.cassandra.cli.CliLexer
-
- PAIR - Static variable in class org.apache.cassandra.cli.CliParser
-
- Pair<T1,T2> - Class in org.apache.cassandra.utils
-
- Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
-
- ParallelCompactionIterable - Class in org.apache.cassandra.db.compaction
-
A class to run compaction taking advantage of multiple-core processes:
One Deserializer thread per input sstable performs read + deserialize (a row at a time).
- ParallelCompactionIterable(OperationType, List<ICompactionScanner>, CompactionController) - Constructor for class org.apache.cassandra.db.compaction.ParallelCompactionIterable
-
- ParallelCompactionIterable(OperationType, List<ICompactionScanner>, CompactionController, int) - Constructor for class org.apache.cassandra.db.compaction.ParallelCompactionIterable
-
- parameters - Variable in class org.apache.cassandra.config.SeedProviderDef
-
- parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- parameters - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- parameters - Variable in class org.apache.cassandra.net.MessageIn
-
- parameters - Variable in class org.apache.cassandra.net.MessageOut
-
- parameters - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- parse(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Parse a string containing an type definition.
- parse(CharSequence) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- parse() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
Parse an AbstractType from current position of this parser.
- parseChunkLength(String) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
-
Parse the chunk length (in KB) and returns it as bytes.
- parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Used by fromString
- parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- parseDefaultParameters(AbstractType<?>, TypeParser) - Static method in class org.apache.cassandra.db.marshal.AbstractType
-
- ParsedStatement - Class in org.apache.cassandra.cql3.statements
-
- ParsedStatement() - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement
-
- ParsedStatement.Prepared - Class in org.apache.cassandra.cql3.statements
-
- ParsedStatement.Prepared(CQLStatement, List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- ParsedStatement.Prepared(CQLStatement, VariableSpecifications) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- ParsedStatement.Prepared(CQLStatement) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- parseStatement(String, QueryState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- parseStatement(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- parseType(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
parse the string to a cassandra data type
- partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- PARTIALLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- PARTITION_FILTER_SIGNATURE - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- partitioner - Variable in class org.apache.cassandra.config.Config
-
- partitioner - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- partitioner - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- partitioner - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- partitioner - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- partitioner() - Method in class org.apache.cassandra.utils.MerkleTree
-
- partitionerClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- partitionKey - Variable in class org.apache.cassandra.service.pager.PagingState
-
- partitionKeyColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- partitionKeyDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- passiveAnnounce(UUID) - Static method in class org.apache.cassandra.service.MigrationManager
-
Announce my version passively over gossip.
- password() - Method in class org.apache.cassandra.cli.CliParser
-
- password - Variable in class org.apache.cassandra.cli.CliSessionState
-
- password - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- password - Variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- PASSWORD_KEY - Static variable in interface org.apache.cassandra.auth.IAuthenticator
-
- PasswordAuthenticator - Class in org.apache.cassandra.auth
-
PasswordAuthenticator is an IAuthenticator implementation
that keeps credentials (usernames and bcrypt-hashed passwords)
internally in C* - in system_auth.credentials CQL3 table.
- PasswordAuthenticator() - Constructor for class org.apache.cassandra.auth.PasswordAuthenticator
-
- patch - Variable in class org.apache.cassandra.utils.SemanticVersion
-
- path - Variable in error org.apache.cassandra.io.FSError
-
- path - Variable in exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- path - Variable in class org.apache.cassandra.io.util.SegmentedFile
-
- pause() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
For internal, temporary suspension of background compactions so that we can do exceptional
things like truncate or major compaction
- pauseHintsDelivery(boolean) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- pauseHintsDelivery(boolean) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
pause hints delivery process
- pauseHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
-
- PAXOS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- PaxosCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- PaxosState - Class in org.apache.cassandra.service.paxos
-
- PaxosState(ByteBuffer, CFMetaData) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
-
- PaxosState(Commit, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
-
- payload - Variable in class org.apache.cassandra.net.MessageIn
-
- payload - Variable in class org.apache.cassandra.net.MessageOut
-
- peer - Variable in class org.apache.cassandra.io.util.Memory
-
- peer - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- peer - Variable in class org.apache.cassandra.streaming.SessionInfo
-
- peer - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- peer - Variable in class org.apache.cassandra.streaming.StreamSession
-
- PEER_EVENTS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- PeerEventsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- PEERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- PeersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- pendingEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- pendingEndpointsFor(Token, String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- pendingRangeChanges(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- pendingTasks - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Estimated number of tasks pending for this column family
- pendingTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Number of pending tasks
- pendingTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Estimated number of compactions remaining to perform
- pendingTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of tasks waiting to be executed.
- percentile(double) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- PerColumnSecondaryIndex - Class in org.apache.cassandra.db.index
-
Base class for Secondary indexes that implement a unique index per column
- PerColumnSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- performCleanup(ColumnFamilyStore, CounterId.OneShotRenewer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- performMaximal(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- performScrub(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- performSSTableRewrite(ColumnFamilyStore, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer, Runnable, WriteType) - Static method in class org.apache.cassandra.service.StorageProxy
-
Perform the write of a mutation given a WritePerformer.
- Permission - Enum in org.apache.cassandra.auth
-
An enum encapsulating the set of possible permissions that an authenticated user can have on a resource.
- permission - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- permission() - Method in class org.apache.cassandra.cql3.CqlParser
-
- PermissionAlteringStatement - Class in org.apache.cassandra.cql3.statements
-
- PermissionAlteringStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- PermissionDetails - Class in org.apache.cassandra.auth
-
Sets of instances of this class are returned by IAuthorizer.listPermissions() method for LIST PERMISSIONS query.
- PermissionDetails(String, IResource, Permission) - Constructor for class org.apache.cassandra.auth.PermissionDetails
-
- permissionOrAll() - Method in class org.apache.cassandra.cql3.CqlParser
-
- permissions - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- permissions_validity_in_ms - Variable in class org.apache.cassandra.config.Config
-
- PerRowSecondaryIndex - Class in org.apache.cassandra.db.index
-
Base class for Secondary indexes that implement a unique index per row
- PerRowSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
-
- PIG_ALLOW_DELETES - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- PIG_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_INPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_INPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_INPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_INPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_INPUT_SPLIT_SIZE - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_OUTPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_OUTPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_OUTPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_OUTPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- PIG_USE_SECONDARY - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- PIG_WIDEROW_INPUT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- pkDef(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
-
- planId - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- planId - Variable in class org.apache.cassandra.streaming.StreamEvent
-
- planId - Variable in class org.apache.cassandra.streaming.StreamResultFuture
-
- planId() - Method in class org.apache.cassandra.streaming.StreamSession
-
- planId - Variable in class org.apache.cassandra.streaming.StreamState
-
- pointInTimeExceeded(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- PoolingSegmentedFile - Class in org.apache.cassandra.io.util
-
- PoolingSegmentedFile(String, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- PoolingSegmentedFile(String, long, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- populate_io_cache_on_flush - Variable in class org.apache.cassandra.config.Config
-
- populateIoCacheOnFlush(boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
- populateIoCacheOnFlush() - Method in class org.apache.cassandra.config.CFMetaData
-
- port() - Method in class org.apache.cassandra.cli.CliParser
-
- port - Variable in class org.apache.cassandra.thrift.ThriftServer
-
- port - Variable in class org.apache.cassandra.tools.AbstractJmxClient
-
- port - Variable in class org.apache.cassandra.transport.SimpleClient
-
- pos - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The current position within the byte array.
- position - Variable in class org.apache.cassandra.cql3.CFDefinition.Name
-
- position() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- position - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- position - Variable in class org.apache.cassandra.db.RowIndexEntry
-
- position() - Method in class org.apache.cassandra.io.util.MemoryOutputStream
-
- position(long) - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- posix_fadvise(int, long, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- postFlushExecutor - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- precision - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- PrecompactedRow - Class in org.apache.cassandra.db.compaction
-
PrecompactedRow merges its rows in its constructor in memory.
- PrecompactedRow(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.db.compaction.PrecompactedRow
-
it is caller's responsibility to call removeDeleted + removeOldShards from the cf before calling this constructor
- PrecompactedRow(CompactionController, List<SSTableIdentityIterator>) - Constructor for class org.apache.cassandra.db.compaction.PrecompactedRow
-
- predicate - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- preheat(Map<DecoratedKey, RowIndexEntry>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- preheat_kernel_page_cache - Variable in class org.apache.cassandra.config.Config
-
- preheatPage(int, long) - Static method in class org.apache.cassandra.utils.CLibrary
-
Suggest kernel to preheat one page for the given file.
- prepare(String, ThriftClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.INRaw
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- prepare(String, String) - Method in class org.apache.cassandra.cql3.Attributes.Raw
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
-
- prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- prepare(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
-
This method validates the operation (i.e.
- prepare(CFDefinition.Name) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
This method validates the operation (i.e.
- prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- prepare(String, ClientState, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
Transform this raw statement into a CreateTableStatement.
- prepare() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- prepare(VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- prepare() - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- prepare(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.Term.Raw
-
This method validates this RawTerm is valid for provided column
specification and "prepare" this RawTerm, returning the resulting
prepared Term.
- prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
-
- prepare(ColumnFamilyStore) - Method in class org.apache.cassandra.repair.Validator
-
- prepare(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- prepare(Collection<StreamRequest>, Collection<StreamSummary>) - Method in class org.apache.cassandra.streaming.StreamSession
-
Prepare this session for sending/receiving files.
- prepare(String) - Method in class org.apache.cassandra.transport.SimpleClient
-
- prepare_cql3_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- prepare_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- PrepareCallback - Class in org.apache.cassandra.service.paxos
-
- PrepareCallback(ByteBuffer, CFMetaData, int) - Constructor for class org.apache.cassandra.service.paxos.PrepareCallback
-
- PreparedQueryNotFoundException - Exception in org.apache.cassandra.exceptions
-
- PreparedQueryNotFoundException(MD5Digest) - Constructor for exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
-
- prepareInternal(CFDefinition, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
-
- prepareInternal(CFDefinition, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- prepareInternal(CFDefinition, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
-
- prepareInternal(CFDefinition, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
-
- prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
-
- prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- PrepareMessage - Class in org.apache.cassandra.streaming.messages
-
- PrepareMessage() - Constructor for class org.apache.cassandra.streaming.messages.PrepareMessage
-
- PrepareMessage - Class in org.apache.cassandra.transport.messages
-
- PrepareMessage(String) - Constructor for class org.apache.cassandra.transport.messages.PrepareMessage
-
- PrepareResponse - Class in org.apache.cassandra.service.paxos
-
- PrepareResponse(boolean, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse
-
- PrepareResponse.PrepareResponseSerializer - Class in org.apache.cassandra.service.paxos
-
- PrepareResponse.PrepareResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- prepareRowMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.AbstractModification
-
Convert statement into a list of mutations to apply on the server
- prepareRowMutations(String, ThriftClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.AbstractModification
-
Convert statement into a list of mutations to apply on the server
- prepareRowMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
-
- prepareRowMutations(String, ThriftClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
-
- prepareRowMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.UpdateStatement
-
Convert statement into a list of mutations to apply on the server
- prepareRowMutations(String, ThriftClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.UpdateStatement
-
Convert statement into a list of mutations to apply on the server
- prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
- prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
prepare writer
- prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
- prepareTracingSession(UUID) - Method in class org.apache.cassandra.service.QueryState
-
- PrepareVerbHandler - Class in org.apache.cassandra.service.paxos
-
- PrepareVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.PrepareVerbHandler
-
- preprocess(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AbstractRowResolver
-
- preprocess(MessageIn<TMessage>) - Method in interface org.apache.cassandra.service.IResponseResolver
-
- preprocess(MessageIn) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- preservesOrder() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- preservesOrder() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- preservesOrder() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
-
- printBanner() - Method in class org.apache.cassandra.cli.CliClient
-
- printClusterDescription(PrintStream, String) - Method in class org.apache.cassandra.tools.NodeCmd
-
Print the name, snitch, partitioner and schema version(s) of a cluster
- printClusterStatus(PrintStream, String) - Method in class org.apache.cassandra.tools.NodeCmd
-
Writes a keyspaceName of cluster-wide node information to a PrintStream
- printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- printCompactionStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- printCompactionThreshold(PrintStream, String, String) - Method in class org.apache.cassandra.tools.NodeCmd
-
Print the compaction threshold
- printCompactionThroughput(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
Print the compaction throughput
- printHelp(String, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
-
- printInfo(PrintStream, NodeCmd.ToolCommandLine) - Method in class org.apache.cassandra.tools.NodeCmd
-
Write node information.
- printNetworkStats(InetAddress, PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- printPendingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- printReleaseVersion(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- printRelocatingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- printRemovalStatus(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- printRing(PrintStream, String) - Method in class org.apache.cassandra.tools.NodeCmd
-
Write a textual representation of the Cassandra ring.
- printStack - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- printStreamThroughput(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
Print the stream throughput
- printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
-
- priority - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- PROBABILITY - Static variable in class org.apache.cassandra.cli.CliLexer
-
- PROBABILITY - Static variable in class org.apache.cassandra.cli.CliParser
-
- process(String, ThriftClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- process(String, ConsistencyLevel, QueryState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- process(String, QueryState, QueryOptions) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- process(String, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- process(List<Row>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- processArgs(CliSessionState, String[]) - Method in class org.apache.cassandra.cli.CliOptions
-
- processArguments(String[]) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
-
- processBatch(BatchStatement, ConsistencyLevel, QueryState, List<List<ByteBuffer>>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- processInboundMessage(MessageIn, int) - Static method in class org.apache.cassandra.net.sink.SinkManager
-
- processInternal(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- processor - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- processOutboundMessage(MessageOut, int, InetAddress) - Static method in class org.apache.cassandra.net.sink.SinkManager
-
- processPrepared(CQLStatement, ThriftClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- processPrepared(CQLStatement, QueryState, QueryOptions) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- processResults(List<Row>, List<ByteBuffer>, int, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- processStatement(String) - Static method in class org.apache.cassandra.cli.CliMain
-
- processStatement(CQLStatement, ThriftClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- processStatementInteractive(String) - Static method in class org.apache.cassandra.cli.CliMain
-
- processWhereClause(List<Relation>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- progress() - Method in class org.apache.cassandra.hadoop.Progressable
-
- progress - Variable in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
-
- progress(Descriptor, ProgressInfo.Direction, long, long) - Method in class org.apache.cassandra.streaming.StreamSession
-
- progressable - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- Progressable - Class in org.apache.cassandra.hadoop
-
- Progressable(TaskAttemptContext) - Constructor for class org.apache.cassandra.hadoop.Progressable
-
- Progressable(Progressable) - Constructor for class org.apache.cassandra.hadoop.Progressable
-
- ProgressInfo - Class in org.apache.cassandra.streaming
-
ProgressInfo contains file transfer progress.
- ProgressInfo(InetAddress, String, ProgressInfo.Direction, long, long) - Constructor for class org.apache.cassandra.streaming.ProgressInfo
-
- ProgressInfo.Direction - Enum in org.apache.cassandra.streaming
-
Direction of the stream.
- ProgressInfoCompositeData - Class in org.apache.cassandra.streaming.management
-
- ProgressInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- promised - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
-
- promised - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- promotedSize() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- properties - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- properties(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
-
- properties - Variable in class org.apache.cassandra.cql3.PropertyDefinitions
-
- properties - Variable in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- property(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
-
- PROPERTY_KEY - Static variable in interface org.apache.cassandra.thrift.ITransportFactory
-
- PropertyDefinitions - Class in org.apache.cassandra.cql3
-
- PropertyDefinitions() - Constructor for class org.apache.cassandra.cql3.PropertyDefinitions
-
- PropertyFileSnitch - Class in org.apache.cassandra.locator
-
Used to determine if two IP's are in the same datacenter or on the same rack.
- PropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
-
- propertyValue() - Method in class org.apache.cassandra.cql3.CqlParser
-
- propose(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- ProposeCallback - Class in org.apache.cassandra.service.paxos
-
ProposeCallback has two modes of operation, controlled by the failFast parameter.
- ProposeCallback(int, int, boolean) - Constructor for class org.apache.cassandra.service.paxos.ProposeCallback
-
- ProposeVerbHandler - Class in org.apache.cassandra.service.paxos
-
- ProposeVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.ProposeVerbHandler
-
- protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- protectedResources() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- protectedResources() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Set of resources that should be made inaccessible to users and only accessible internally.
- protectedResources() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Set of resources that should be made inaccessible to users and only accessible internally.
- protectedResources() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- protectedResources() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- protectedResources() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- PROTOCOL_MAGIC - Static variable in class org.apache.cassandra.net.MessagingService
-
we preface every message with this number so the recipient can validate the sender is sane
- ProtocolException - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ProtocolException(String) - Constructor for exception org.apache.cassandra.transport.ProtocolException
-
- prune(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- prune(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- PureJavaCrc32 - Class in org.apache.cassandra.utils
-
A pure-java implementation of the CRC32 checksum that uses
the same polynomial as the built-in native CRC32.
- PureJavaCrc32() - Constructor for class org.apache.cassandra.utils.PureJavaCrc32
-
Create a new PureJavaCrc32 object.
- purge(CFMetaData) - Method in class org.apache.cassandra.config.Schema
-
Used for ColumnFamily data eviction out from the schema
- purge(int) - Method in class org.apache.cassandra.db.DeletionInfo
-
Purge every tombstones that are older than gcbefore
.
- purge(int) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Removes all range tombstones whose local deletion time is older than gcBefore.
- put(K, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- put(K, V) - Method in interface org.apache.cassandra.cache.ICache
-
- put(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- put(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- put(String, Object) - Method in class org.apache.cassandra.cql3.UserOptions
-
- put(K) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
enqueues the given value to Cassandra
- put(RandomAccessReader) - Method in class org.apache.cassandra.service.FileCacheService
-
- put(K, V) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- put(K, V) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- put(K, V, long) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- putIfAbsent(K, V) - Method in interface org.apache.cassandra.cache.ICache
-
- putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
write next row
- putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
output: (((name, value), (name, value)), (value ...
- putShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- R - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql.CqlParser
-
- R - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- r1 - Variable in class org.apache.cassandra.repair.Differencer
-
- r2 - Variable in class org.apache.cassandra.repair.Differencer
-
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rack_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Rack
-
- RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
-
- RackInferringSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded
in the 2nd and 3rd octets of the ip address, respectively.
- RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
-
- racks - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- RandomAccessReader - Class in org.apache.cassandra.io.util
-
- RandomAccessReader(File, int, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
-
- RandomAccessReader.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
-
Class to hold a mark to the position of the file
- RandomAccessReader.BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader.BufferedRandomAccessFileMark
-
- RandomPartitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using MD5 hash.
- RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
-
- Range<T extends RingPosition> - Class in org.apache.cassandra.dht
-
A representation of the range that a node is responsible for on the DHT ring.
- Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
-
- Range(T, T, IPartitioner) - Constructor for class org.apache.cassandra.dht.Range
-
- range - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
repairing range
- range - Variable in class org.apache.cassandra.repair.RepairSession
-
Range to repair
- range_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RANGE_TOMBSTONE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- RANGE_XFERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- rangeCovering(ByteBuffer) - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeIterator() - Method in class org.apache.cassandra.db.DeletionInfo
-
- RangeNamesQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a name query.
- RANGEOP - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- RANGEOP - Static variable in class org.apache.cassandra.cql.CqlParser
-
- ranges - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
-
- RangeSliceCommand - Class in org.apache.cassandra.db
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a slice query.
- RangeSliceReply - Class in org.apache.cassandra.db
-
- RangeSliceReply(List<Row>) - Constructor for class org.apache.cassandra.db.RangeSliceReply
-
- RangeSliceResponseResolver - Class in org.apache.cassandra.service
-
Turns RangeSliceReply objects into row (string -> CF) maps, resolving
to the most recent ColumnFamily and setting up read repairs as necessary.
- RangeSliceResponseResolver(String, long) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
-
- RangeSliceVerbHandler - Class in org.apache.cassandra.service
-
- RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
-
- RangeStreamer - Class in org.apache.cassandra.dht
-
Assists in streaming ranges to a node.
- RangeStreamer(TokenMetadata, InetAddress, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer
-
- RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not alive according to a
failure detector.
- RangeStreamer.FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- 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.
- RangeStreamer.SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- RangeTombstone - Class in org.apache.cassandra.db
-
- RangeTombstone(ByteBuffer, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone(ByteBuffer, ByteBuffer, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone.Serializer - Class in org.apache.cassandra.db
-
- RangeTombstone.Serializer() - Constructor for class org.apache.cassandra.db.RangeTombstone.Serializer
-
- RangeTombstone.Tracker - Class in org.apache.cassandra.db
-
- RangeTombstone.Tracker(Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.RangeTombstone.Tracker
-
- RangeTombstoneList - Class in org.apache.cassandra.db
-
Data structure holding the range tombstones of a ColumnFamily.
- RangeTombstoneList(Comparator<ByteBuffer>, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
-
- RangeTombstoneList.InOrderTester - Class in org.apache.cassandra.db
-
This object allow testing whether a given column (name/timestamp) is deleted
or not by this RangeTombstoneList, assuming that the column given to this
object are passed in (comparator) sorted order.
- RangeTombstoneList.InOrderTester() - Constructor for class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- RangeTombstoneList.Serializer - Class in org.apache.cassandra.db
-
- RangeXfersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- rawAppend(ColumnFamily, long, DecoratedKey, DataOutput) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- RawSelector - Class in org.apache.cassandra.cql3.statements
-
- RawSelector(Selectable, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.statements.RawSelector
-
- read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
-
- read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- read() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads a single byte from the source byte array and returns it as an
integer in the range from 0 to 255.
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads at most len
bytes from this stream and stores
them in byte array b
starting at offset
.
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(DataInput, int, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
- read() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.StreamReader
-
- read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- read() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- read_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a boolean from the current position in this file.
- readBoolean() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an 8-bit byte from the current position in this file.
- readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readBytes(int) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
Read length bytes from current file position
- readBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
Does the same thing as readFully
do but without copying data (thread safe)
- readBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- readBytes(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadCallback<TMessage,TResolved> - Class in org.apache.cassandra.service
-
- ReadCallback(IResponseResolver<TMessage, TResolved>, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
-
Constructor when response count has to be calculated and blocked for.
- readChar() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 16-bit character from the current position in this file.
- readChar() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readColumnFamily(List<ReadCommand>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- ReadCommand - Class in org.apache.cassandra.db
-
- ReadCommand(String, ByteBuffer, String, long, ReadCommand.Type) - Constructor for class org.apache.cassandra.db.ReadCommand
-
- ReadCommand.Type - Enum in org.apache.cassandra.db
-
- readConsistencyLevel(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readDouble() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit double from the current position in this file.
- readDouble() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readEnumValue(Class<T>, ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- readFloat() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit float from the current position in this file.
- readFloat() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads bytes from this file into buffer
.
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Read bytes from this file into buffer
starting at offset offset
.
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInet(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit integer from the current position in this file.
- readInt() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInt() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Read metrics
- readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a line of text form the current position in this file.
- readLine() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit long from the current position in this file.
- readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readLongString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readNextChar() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readRawBytes(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- ReadRepairDecision - Enum in org.apache.cassandra.config
-
- ReadRepairMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Read Repair.
- ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
-
- ReadRepairVerbHandler - Class in org.apache.cassandra.db
-
- ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
-
- readRequiredRows(List<ByteBuffer>, ColumnNameBuilder, boolean, ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- ReadResponse - Class in org.apache.cassandra.db
-
- ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- readSchemaRow(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- readSchemaRow(String, String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Fetches a subset of schema (table data, columns metadata or triggers) for the keyspace+table pair.
- readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 16-bit short from the current position in this file.
- readShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringList(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringToStringListMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadTimeoutException - Exception in org.apache.cassandra.exceptions
-
- ReadTimeoutException(ConsistencyLevel, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- readTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Reads the list of components from the TOC component.
- readUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 8-bit byte from the current position in this file and
returns it as an integer.
- readUnsignedByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 16-bit short from the current position in this file and
returns it as an integer.
- readUnsignedShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a string that is encoded in modified UTF-8
from
this file.
- readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUUID(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ChannelBuffer) - Method in enum org.apache.cassandra.transport.DataType
-
- readValue(ChannelBuffer) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- readValueList(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadVerbHandler - Class in org.apache.cassandra.db
-
- ReadVerbHandler() - Constructor for class org.apache.cassandra.db.ReadVerbHandler
-
- readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadyMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- ReadyMessage() - Constructor for class org.apache.cassandra.transport.messages.ReadyMessage
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
Read data from file starting from current currentOffset to populate buffer.
- reBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- reBuffer() - Method in class org.apache.cassandra.io.util.ThrottledReader
-
- rebuild() - Method in class org.apache.cassandra.config.CFMetaData
-
- rebuild(String) - Method in class org.apache.cassandra.service.StorageService
-
- rebuild(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Initiate a process of streaming data for which we are responsible from other nodes.
- rebuild(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- rebuildSecondaryIndex(String, String, String...) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- rebuildSecondaryIndex(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- rebuildSecondaryIndex(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
rebuild the specified indexes
- receive(MessageIn, int, long) - Method in class org.apache.cassandra.net.MessagingService
-
- receive(FileMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after receiving FileMessageHeader.
- received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
-
- received(SSTableReader) - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
Process received file.
- received(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
- ReceivedMessage - Class in org.apache.cassandra.streaming.messages
-
- ReceivedMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
-
- receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
-
- receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of receiving summaries
- recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Number of false positives in bloom filter from last read
- recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
False positive ratio of bloom filter from last read
- recentLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- recentSSTablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- recognizedOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- reconcile(Column) - Method in class org.apache.cassandra.db.Column
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.Column
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.CounterColumn
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.DeletedColumn
-
- ReconnectableSnitchHelper - Class in org.apache.cassandra.locator
-
Sidekick helper for snitches that want to reconnect from one IP addr for a node to another.
- ReconnectableSnitchHelper(IEndpointSnitch, String, boolean) - Constructor for class org.apache.cassandra.locator.ReconnectableSnitchHelper
-
- recordColumnDrop(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- recover() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on commit logs located in the directory specified by the config file.
- recover(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a list of commit log files.
- recover(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a single commit log.
- recover(String) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Recover a single file.
- recover(File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- recover(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- recvBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- recycle() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Recycle processes an unneeded segment file for reuse.
- recycle(RandomAccessReader) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- recycleSegment(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Indicates that a segment is no longer in use and that it should be recycled.
- recycleSegment(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Differs from the above because it can work on any file instead of just existing
commit log segments managed by this allocator.
- reduce(OnDiskAtomIterator) - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- reduce(In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
combine this object with the previous ones.
- reducer - Variable in class org.apache.cassandra.utils.MergeIterator
-
- reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Called if no disk is available with free space for the full write size.
- 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
-
- 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
-
- refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
-
- register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
-
Register for interesting state changes.
- register(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
-
- register(IMigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
-
- register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
-
- register(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Register interest for Failure Detector events.
- RegisterMessage - Class in org.apache.cassandra.transport.messages
-
- RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
-
- 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.
- regularColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- regularColumnsToFetch() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- regularDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- relation() - Method in class org.apache.cassandra.cql.CqlParser
-
- Relation - Class in org.apache.cassandra.cql
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- Relation(Term, String, Term) - Constructor for class org.apache.cassandra.cql.Relation
-
Creates a new relation.
- relation(List<Relation>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- Relation - Class in org.apache.cassandra.cql3
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- Relation(ColumnIdentifier, Relation.Type, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Relation
-
Creates a new relation.
- Relation(ColumnIdentifier, Relation.Type, Term.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.Relation
-
- Relation.Type - Enum in org.apache.cassandra.cql3
-
- relationType() - Method in class org.apache.cassandra.cql3.CqlParser
-
- relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
- release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
-
A convenience method for indicating when a particular request has completed
processing, and before a return to the client
- release() - Method in class org.apache.cassandra.scheduler.NoScheduler
-
- release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- releaseReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Release reference to this SSTableReader.
- releaseReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- releaseSummary() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- reload() - Method in class org.apache.cassandra.config.CFMetaData
-
- reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- reload() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Reload an existing index following a change to its configuration,
or that of the indexed column(s).
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Drops and adds new indexes associated with the underlying CF
- reloadAttributes() - Method in class org.apache.cassandra.config.KSMetaData
-
- reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
-
Reload the triggers which is already loaded, Invoking this will update
the class loader so new jars can be loaded.
- reloadConfiguration() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- reloadSecondaryIndexMetadata(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Reloads the sstable metadata from disk.
- reloadTriggerClass() - Method in class org.apache.cassandra.service.StorageProxy
-
- reloadTriggerClass() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- relocate(Collection<String>) - Method in class org.apache.cassandra.service.StorageService
-
- relocate(Collection<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- relocating(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- remaining - Variable in class org.apache.cassandra.service.pager.PagingState
-
- remainingBodyLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- remainingCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- remainingHeaderLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- remove(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- remove(K) - Method in interface org.apache.cassandra.cache.ICache
-
- remove(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- remove(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- remove() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- remove(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- remove(Column) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when lazy-updating the index during compaction (CASSANDRA-2897)
- remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
remove endpoint from failure detector
- remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removeDeleted(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removeDeletedAndOldShards(DecoratedKey, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- removeDeletedAndOldShards(DecoratedKey, boolean, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removeDeletedColumnsOnly(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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
-
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
Removes current DC/rack assignment for ep
- removeFromActiveSessions(RepairSession) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from moving endpoints
- removeFromRelocating(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from relocating ranges.
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Delete all files and references to this index
- removeIndexedColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Removes a existing index
- removeKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace from schema
- removeNode(String) - Method in class org.apache.cassandra.service.StorageService
-
Remove a node that has died, attempting to restore the replica count.
- removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
removeToken removes token (and all data associated with
enpoint that had it) from the ring
- removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeOldShards(ByteBuffer, int) - Method in class org.apache.cassandra.db.context.CounterContext
-
Remove shards that have been canceled through computeOldShardMerger
since a time older than gcBefore.
- removeRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- removeTrigger(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
This method is used to remove information about truncation time for specified column family
- removeUnfinishedCompactionLeftovers(String, String, Set<Integer>) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Replacing compacted sstables is atomic as far as observers of DataTracker are concerned, but not on the
filesystem: first the new sstables are renamed to "live" status (i.e., the tmp marker is removed), then
their ancestors are removed.
- removeUnreadableSSTables(File) - Static method in class org.apache.cassandra.db.Keyspace
-
Removes every SSTable in the directory from the appropriate DataTracker's view.
- removeValue(V) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removingNonlocal(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rename(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- renameColumn(ByteBuffer, String, ByteBuffer, String) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- renewLocalId() - Static method in class org.apache.cassandra.utils.CounterId
-
Renew the local counter id.
- renewLocalId(long) - Static method in class org.apache.cassandra.utils.CounterId
-
- renewMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
Renew the current memtable without putting the old one for a flush.
- repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- RepairException - Exception in org.apache.cassandra.exceptions
-
Exception thrown during repair
- RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairException(RepairJobDesc, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairFuture - Class in org.apache.cassandra.repair
-
- RepairFuture(RepairSession) - Constructor for class org.apache.cassandra.repair.RepairFuture
-
- RepairJob - Class in org.apache.cassandra.repair
-
RepairJob runs repair on given ColumnFamily.
- RepairJob(UUID, String, String, Range<Token>, boolean) - 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, String, String, Range<Token>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
-
- RepairMessage - Class in org.apache.cassandra.repair.messages
-
Base class of all repair related request/response messages.
- RepairMessage(RepairMessage.Type, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
-
- RepairMessage.MessageSerializer<T extends RepairMessage> - Interface in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- RepairMessage.Type - Enum in org.apache.cassandra.repair.messages
-
- RepairMessageVerbHandler - Class in org.apache.cassandra.repair
-
Handles all repair related message.
- RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- repairOverlappingSSTables(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- repairResults - Variable in class org.apache.cassandra.service.RowDataResolver
-
- RepairSession - Class in org.apache.cassandra.repair
-
Coordinates the (active) repair of a token range.
- RepairSession(Range<Token>, String, boolean, boolean, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
-
Create new repair session.
- RepairSession(UUID, Range<Token>, String, boolean, boolean, String[]) - Constructor for class org.apache.cassandra.repair.RepairSession
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- replace(K, V, V) - Method in interface org.apache.cassandra.cache.ICache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.ColumnFamily
-
Replace oldColumn if present by newColumn.
- replace(Iterable<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.EmptyColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- replaceCompactedSSTables(Collection<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- replaceCompactedSSTables(Collection<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
-
- replacedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
- replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
-
- ReplayPosition - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- replayPosition(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition.ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- replica_placement_strategy() - Method in class org.apache.cassandra.cli.CliParser
-
- replicasMissingMostRecentCommit() - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- replicateOnWrite(boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
- REPLICATION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.KSPropDefs
-
- ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
-
- ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
-
- replies - Variable in class org.apache.cassandra.service.AbstractRowResolver
-
- report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by the receiver of the heartbeat.
- reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliLexer
-
- reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliParser
-
- reportSeverity(double) - Method in class org.apache.cassandra.service.StorageService
-
Increment about the known Compaction severity of the events in this node
- representJavaBeanProperty(Object, Property, Object, Tag) - Method in class org.apache.cassandra.utils.SkipNullRepresenter
-
- request - Variable in class org.apache.cassandra.repair.StreamingRepairTask
-
- 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
-
- RequestCoordinator<R> - Class in org.apache.cassandra.repair
-
- RequestCoordinator(boolean) - Constructor for class org.apache.cassandra.repair.RequestCoordinator
-
- 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
-
- requestGC() - Method in class org.apache.cassandra.service.StorageService
-
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- requestRanges(InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in keyspace
and ranges
from specific node.
- requestRanges(InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in columnFamilies
under keyspace
and ranges
from specific node.
- requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total number of cache requests
- requests - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
-
Total number of requests
- requests - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Streaming requests
- RequestSchedulerOptions - Class in org.apache.cassandra.config
-
- RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
-
- RequestThreadPoolExecutor - Class in org.apache.cassandra.transport
-
- RequestThreadPoolExecutor() - Constructor for class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- RequestTimeoutException - Exception in org.apache.cassandra.exceptions
-
- RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- RequestType - Enum in org.apache.cassandra.thrift
-
- RequestValidationException - Exception in org.apache.cassandra.exceptions
-
- RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Whether or not the authenticator requires explicit login.
- requireAuthentication() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
-
- REQUIRES_KEYSPACE - Static variable in enum org.apache.cassandra.cql.StatementType
-
Statement types that require a keyspace to be set
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Operation
-
- rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
-
- rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
Retry all deletions that failed the first time around (presumably b/c the sstable was still mmap'd.)
Useful because there are times when we know GC has been invoked; also exposed as an mbean.
- reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Resets this stream to the last marked location.
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Resets this stream to the beginning of the underlying byte array.
- reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
reconnect to @param remoteEP (after the current message backlog is exhausted).
- reset(long) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
reset counter to @param count
- reset() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- reset() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- reset() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- reset() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Reset the writer so that the next chunk offset written will be the
one of chunkIndex
.
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetChecksum() - Method in class org.apache.cassandra.io.util.ChecksummedOutputStream
-
- 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
-
- resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Resets all the segments, for testing purposes.
- resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- resolve(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
-
- resolve(ColumnFamily, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
-
- resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
-
This Method resolves the responses that are passed in .
- resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDataResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
-
- resolver - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- resolver - Variable in class org.apache.cassandra.service.ReadCallback
-
- resource - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- resource() - Method in class org.apache.cassandra.cql3.CqlParser
-
- resource - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- Resources - Class in org.apache.cassandra.auth
-
- Resources() - Constructor for class org.apache.cassandra.auth.Resources
-
- resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ResourceWatcher - Class in org.apache.cassandra.utils
-
- ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
-
- ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
-
- ResourceWatcher.WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- 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.service.AbstractWriteResponseHandler
-
null message means "response from local write"
- response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- response(MessageIn<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- response(MessageIn<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- response(MessageIn<TMessage>) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(TMessage) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- response(MessageIn) - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- responseCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
-
- responsePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
-
- ResponseVerbHandler - Class in org.apache.cassandra.net
-
- ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
-
- restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- Restriction - Interface in org.apache.cassandra.cql3.statements
-
A restriction/clause on a column.
- Restriction.EQ - Class in org.apache.cassandra.cql3.statements
-
- Restriction.EQ(Term, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- Restriction.IN - Class in org.apache.cassandra.cql3.statements
-
- Restriction.IN() - Constructor for class org.apache.cassandra.cql3.statements.Restriction.IN
-
- Restriction.Slice - Class in org.apache.cassandra.cql3.statements
-
- Restriction.Slice(boolean) - Constructor for class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- ResultMessage - Class in org.apache.cassandra.transport.messages
-
- ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
-
- ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared(MD5Digest, ParsedStatement.Prepared) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ResultMessage.SchemaChange.Change - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- ResultMessage.Void - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- ResultSet - Class in org.apache.cassandra.cql3
-
- ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet(ResultSet.Metadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet.Codec - Class in org.apache.cassandra.cql3
-
- ResultSet.Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
-
- ResultSet.Flag - Enum in org.apache.cassandra.cql3
-
- ResultSet.Metadata - Class in org.apache.cassandra.cql3
-
- ResultSet.Metadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.Metadata
-
- resultSetBuilder(long) - Method in class org.apache.cassandra.cql3.statements.Selection
-
- resume() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
For internal, temporary suspension of background compactions so that we can do exceptional
things like truncate or major compaction
- resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
-
- rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
-
- RetriedSliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- retry(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.RETRY
message.
- RetryMessage - Class in org.apache.cassandra.streaming.messages
-
- RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
-
- returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- reverse() - Method in class org.apache.cassandra.cql3.ResultSet
-
- reverse(Bound) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
- reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- reversedExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- ReversedType<T> - Class in org.apache.cassandra.db.marshal
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.EmptyColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Revokes a set of permissions on a resource from a user.
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called before deleting a user with DROP USER query so that a new user with the same
name wouldn't inherit permissions of the deleted user in the future.
- revokeAll(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called after a resource is removed (i.e.
- revokeAll(String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- RevokeStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokeStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.RevokeStatement
-
- right - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- right - Variable in class org.apache.cassandra.utils.Pair
-
- RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
-
- RingCache - Class in org.apache.cassandra.client
-
A class for caching the ring map at the client.
- RingCache(Configuration) - Constructor for class org.apache.cassandra.client.RingCache
-
- ringCache - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
iterator over the Tokens in the given ring, starting with the token for the node owning start
(which does not have to be a Token in the ring)
- RingPosition<T> - Interface in org.apache.cassandra.dht
-
Interface representing a position on the ring.
- root() - Static method in class org.apache.cassandra.auth.DataResource
-
- ROOT - Static variable in class org.apache.cassandra.auth.Resources
-
Deprecated.
- root() - Method in class org.apache.cassandra.cli.CliParser
-
- rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- RoundRobinScheduler - Class in org.apache.cassandra.scheduler
-
A very basic Round Robin implementation of the RequestScheduler.
- RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- roundTo(long, int) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- row() - Method in class org.apache.cassandra.db.ReadResponse
-
- Row - Class in org.apache.cassandra.db
-
- Row(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row.RowSerializer - Class in org.apache.cassandra.db
-
- Row.RowSerializer() - Constructor for class org.apache.cassandra.db.Row.RowSerializer
-
- row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- row_cache_save_period - Variable in class org.apache.cassandra.config.Config
-
- row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- rowCache - Variable in class org.apache.cassandra.service.CacheService
-
- RowCacheKey - Class in org.apache.cassandra.cache
-
- RowCacheKey(UUID, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(UUID, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheSentinel - Class in org.apache.cassandra.cache
-
A sentinel object for row caches.
- RowCacheSentinel() - Constructor for class org.apache.cassandra.cache.RowCacheSentinel
-
- RowDataResolver - Class in org.apache.cassandra.service
-
- RowDataResolver(String, ByteBuffer, IDiskAtomFilter, long) - Constructor for class org.apache.cassandra.service.RowDataResolver
-
- RowDigestResolver - Class in org.apache.cassandra.service
-
- RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
-
- rowFilter - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- RowIndexEntry - Class in org.apache.cassandra.db
-
- RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
-
- RowIndexEntry.Serializer - Class in org.apache.cassandra.db
-
- RowIndexEntry.Serializer() - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- RowIteratorFactory - Class in org.apache.cassandra.db
-
- RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
-
- rowKey() - Method in class org.apache.cassandra.cli.CliParser
-
- rowLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- rowMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- RowMutation - Class in org.apache.cassandra.db
-
- RowMutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, ByteBuffer, Map<UUID, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation.RowMutationSerializer - Class in org.apache.cassandra.db
-
- RowMutation.RowMutationSerializer() - Constructor for class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- RowMutationVerbHandler - Class in org.apache.cassandra.db
-
- RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
-
- RowPosition - Class in org.apache.cassandra.db
-
- RowPosition() - Constructor for class org.apache.cassandra.db.RowPosition
-
- RowPosition.Kind - Enum in org.apache.cassandra.db
-
- RowPosition.RowPositionSerializer - Class in org.apache.cassandra.db
-
- RowPosition.RowPositionSerializer() - Constructor for class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- rows - Variable in class org.apache.cassandra.cql3.ResultSet
-
- rows - Variable in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- rows - Variable in class org.apache.cassandra.db.RangeSliceReply
-
- rowsOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowsOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowValue() - Method in class org.apache.cassandra.cli.CliParser
-
- rpc_address - Variable in class org.apache.cassandra.config.Config
-
- rpc_keepalive - 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
-
- run() - Method in class org.apache.cassandra.db.MeteredFlusher
-
- run - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- run() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
Loops collecting mutations from the queue and sending to Cassandra
- run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- run() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
A new connection will either stream or message for its entire lifetime: because streaming
bypasses the InputStream implementations to use sendFile, we cannot begin buffering until
we've determined the type of the connection.
- run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
-
- run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- run() - Method in class org.apache.cassandra.repair.Differencer
-
Compares our trees, and triggers repairs for any ranges that mismatch.
- run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
- run() - Method in class org.apache.cassandra.repair.Validator
-
Called after the validation lifecycle to respond with the now valid tree.
- run() - Method in class org.apache.cassandra.transport.Client
-
- run() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor.BackgroundActivityReporter
-
- run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- run() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runMayThrow() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Run this task after selecting the optimal disk for it
- runMayThrow() - Method in class org.apache.cassandra.repair.RepairSession
-
- runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runWith(File) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
For internal use and testing only.
- runWith(File) - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Executes this task on given sstableDirectory
.
- runWithCompactionsDisabled(Callable<V>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- S - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- S - Static variable in class org.apache.cassandra.cql.CqlParser
-
- S - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- S - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- 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
-
- sampleLatency - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- satisfies(int, IndexOperator) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- saveCaches() - Method in class org.apache.cassandra.service.CacheService
-
- saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
save row and key caches
- saved_caches_directory - Variable in class org.apache.cassandra.config.Config
-
- savePaxosCommit(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosPromise(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- saveSummary(SSTableReader, SegmentedFile.Builder, SegmentedFile.Builder) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- schedule() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- ScheduledRangeTransferExecutorService - Class in org.apache.cassandra.service
-
- ScheduledRangeTransferExecutorService() - Constructor for class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
-
- scheduledTasks - Static variable in class org.apache.cassandra.service.StorageService
-
This pool is used for periodic short (sub-second) tasks.
- scheduleHintDelivery(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
force hint delivery to an endpoint
- scheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowDataResolver
-
For each row version, compare with resolved (the superset of all row versions);
if it is missing anything, send a mutation to the endpoint it come from.
- scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- SCHEMA - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SCHEMA - Static variable in class org.apache.cassandra.cli.CliParser
-
- Schema - Class in org.apache.cassandra.config
-
- Schema() - Constructor for class org.apache.cassandra.config.Schema
-
Initialize empty schema object
- schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- SCHEMA_COLUMNFAMILIES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_COLUMNS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_KEYSPACES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_TRIGGERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SchemaAlteringStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that alter the schema.
- SchemaAlteringStatement() - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- SchemaAlteringStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- schemaCFS(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- SchemaCheckVerbHandler - Class in org.apache.cassandra.db
-
- SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- SchemaColumnFamiliesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaColumnsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaKeyspacesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaTriggersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- scName - Variable in class org.apache.cassandra.db.SuperColumns.SCFilter
-
- scName(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- scrub(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- scrub(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace.
- scrub(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Scrubber - Class in org.apache.cassandra.db.compaction
-
- Scrubber(ColumnFamilyStore, SSTableReader) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, SSTableReader, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- scrubDataDirectories(String, String) - 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.
- search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Performs a search across a number of column indexes
TODO: add support for querying across index types
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- search(ByteBuffer) - 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.
- search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
-
- search(C) - Method in class org.apache.cassandra.utils.IntervalTree
-
- searchComposite(String, boolean) - Static method in class org.apache.cassandra.db.DefsTables
-
- SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
-
- SecondaryIndex - Class in org.apache.cassandra.db.index
-
Abstract base class for different types of secondary indexes.
- SecondaryIndex() - Constructor for class org.apache.cassandra.db.index.SecondaryIndex
-
- SecondaryIndexBuilder - Class in org.apache.cassandra.db.index
-
Manages building an entire index from column family data.
- SecondaryIndexBuilder(ColumnFamilyStore, Set<String>, ReducingKeyIterator) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexBuilder
-
- SecondaryIndexManager - Class in org.apache.cassandra.db.index
-
Manages all the indexes associated with a given CFS
Different types of indexes can be created across the same CF
- SecondaryIndexManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexManager
-
- SecondaryIndexManager.Updater - Interface in org.apache.cassandra.db.index
-
- SecondaryIndexSearcher - Class in org.apache.cassandra.db.index
-
- SecondaryIndexSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- sections - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamReader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sections - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- seed_provider - Variable in class org.apache.cassandra.config.Config
-
- SeedProvider - Interface in org.apache.cassandra.locator
-
- SeedProviderDef - Class in org.apache.cassandra.config
-
- SeedProviderDef(LinkedHashMap<String, ?>) - Constructor for class org.apache.cassandra.config.SeedProviderDef
-
- seek(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- seek(long) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- seekInternal(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
-
- segment - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- SegmentedFile - Class in org.apache.cassandra.io.util
-
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent
FileDataInput.
- SegmentedFile(String, long, long) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
-
- SegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
Collects potential segmentation points in an underlying file, and builds a SegmentedFile to represent it.
- SegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- selectable - Variable in class org.apache.cassandra.cql3.statements.RawSelector
-
- Selectable - Interface in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction(String, List<Selectable>) - Constructor for class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WritetimeOrTTL(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- selectClause() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selectCountClause() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selectExpression() - Method in class org.apache.cassandra.cql.CqlParser
-
- SelectExpression - Class in org.apache.cassandra.cql
-
Select expressions are analogous to the projection in a SQL query.
- SelectExpression(Term, Term, int, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a range (slice) of columns.
- SelectExpression(Term, int, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a list of columns.
- selectFullRow - Variable in class org.apache.cassandra.db.DataRange
-
- Selection - Class in org.apache.cassandra.cql3.statements
-
- Selection(List<CFDefinition.Name>, List<ColumnSpecification>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selection
-
- Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.statements
-
- selectionFunctionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selector() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
-
- selectStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- SelectStatement - Class in org.apache.cassandra.cql
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(SelectExpression, boolean, String, String, ConsistencyLevel, WhereClause, int) - Constructor for class org.apache.cassandra.cql.SelectStatement
-
- selectStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- SelectStatement - Class in org.apache.cassandra.cql3.statements
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(CFDefinition, int, SelectStatement.Parameters, Selection, Term) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
-
- SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.Parameters(Map<ColumnIdentifier, Boolean>, boolean, boolean, ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.RawStatement(CFName, SelectStatement.Parameters, List<RawSelector>, List<Relation>, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- SemanticVersion - Class in org.apache.cassandra.utils
-
Implements semantic versioning as defined at http://semver.org/.
- SemanticVersion(String) - Constructor for class org.apache.cassandra.utils.SemanticVersion
-
Parse a semantic version from a string.
- SEMICOLON - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SEMICOLON - Static variable in class org.apache.cassandra.cli.CliParser
-
- send(R) - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- sendBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- sendingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of sending summaries
- sendMessage(StreamMessage) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- sendMessages(Collection<? extends StreamMessage>) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Enqueue messages to be sent.
- sendNotification(String, String, Object) - Method in class org.apache.cassandra.service.StorageService
-
Sends JMX notification to subscribers.
- sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendOneWay(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- sendReply(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback, long) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendToHintedEndpoints(RowMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, String, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node
is not available.
- sendTreeRequests(Collection<InetAddress>) - Method in class org.apache.cassandra.repair.RepairJob
-
Send merkle tree request to every involved neighbor.
- sentMessage - Variable in class org.apache.cassandra.net.CallbackInfo
-
- separator - Static variable in class org.apache.cassandra.io.sstable.Component
-
- 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
-
- SequentialWriter - Class in org.apache.cassandra.io.util
-
- SequentialWriter(File, int, boolean) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
-
- SequentialWriter.BufferedFileWriterMark - Class in org.apache.cassandra.io.util
-
Class to hold a mark to the position of the file
- SequentialWriter.BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
-
- serializationFlags() - Method in class org.apache.cassandra.db.Column
-
- serializationFlags() - Method in class org.apache.cassandra.db.CounterColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.DeletedColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- serialize(K, DataOutput) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- serialize(ColumnFamily, DataOutput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serialize(Column, DataOutput) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serialize(ReplayPosition, DataOutput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serialize(DeletionInfo, DataOutput, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serialize(ColumnSlice, DataOutput, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serialize(IDiskAtomFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serialize(NamesQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serialize(DataOutput) - Method in class org.apache.cassandra.db.filter.QueryPath
-
- serialize(SliceQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.MapType
-
Creates the same output than serialize, but from the internal representation.
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- serialize(RangeTombstoneList, DataOutput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serialize(Row, DataOutput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serialize(RowIndexEntry, DataOutput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serialize(RowMutation, DataOutput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- serialize(RowPosition, DataOutput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serialize(TruncateResponse, DataOutput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serialize(WriteResponse, DataOutput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serialize(AbstractBounds<?>, DataOutput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serialize(String, DataOutput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serialize(Token, DataOutput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serialize(EchoMessage, DataOutput, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- serialize(T, DataOutput) - Method in interface org.apache.cassandra.io.ISerializer
-
Serialize the specified type into the specified DataOutput instance.
- serialize(T, DataOutput, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- serialize(IndexSummary, DataOutputStream) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- serialize(SSTableMetadata, Set<Integer>, DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serialize(DataOutputStream, int) - Method in class org.apache.cassandra.net.MessageOut
-
- serialize(RepairMessage, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serialize(SyncRequest, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serialize(ValidationRequest, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serialize(NodePair, DataOutput, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- serialize(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
Layout is: <n><s_1><b_1>...<s_n><b_n>
where:
n is the number of elements
s_i is the number of bytes composing the ith element
b_i is the s_i bytes composing the ith element
- serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- serialize(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
Layout is: <n><sk_1><k_1><sv_1><v_1>...<sk_n><k_n><sv_n><v_n>
where:
n is the number of elements
sk_i is the number of bytes composing the ith key k_i
k_i is the sk_i bytes composing the ith key
sv_i is the number of bytes composing the ith value v_i
v_i is the sv_i bytes composing the ith value
- serialize(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
Layout is: <n><s_1><b_1>...<s_n><b_n>
where:
n is the number of elements
s_i is the number of bytes composing the ith element
b_i is the s_i bytes composing the ith element
- 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(KeyCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- serialize(RowCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- serialize(Collection<RowMutation>, DataOutput, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serialize() - Method in class org.apache.cassandra.service.pager.PagingState
-
- serialize(Commit, DataOutput, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serialize(PrepareResponse, DataOutput, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serialize(StreamMessage, WritableByteChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- serialize(V, WritableByteChannel, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- serialize(StreamRequest, DataOutput, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serialize(StreamSummary, DataOutput, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serialize(ChannelBuffer) - 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, DataOutput, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serialize(EstimatedHistogram, DataOutput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serialize(TSerializer, TBase, DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Deprecated.
- serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- serialize(IFilter, DataOutput) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- serialize(IntervalTree<C, D, I>, DataOutput, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serialize(MerkleTree, DataOutput, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serialize(DataOutput) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serialize(StreamingHistogram, DataOutput) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serialize(UUID, DataOutput, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- serializeCfId(UUID, DataOutput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- serializedSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializedSchema(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.Column
-
- serializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(ColumnFamily, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(Column, TypeSizes) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serializedSize(ReplayPosition, TypeSizes) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.CounterColumn
-
- serializedSize(DeletionInfo, TypeSizes, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(DeletionInfo, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- serializedSize(ColumnSlice, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serializedSize(IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serializedSize(NamesQueryFilter, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.filter.QueryPath
-
- serializedSize(SliceQueryFilter, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serializedSize(TypeSizes) - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.RangeTombstone
-
- serializedSize(RangeTombstoneList, TypeSizes, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(RangeTombstoneList, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(Row, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serializedSize() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- serializedSize(RowMutation, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- serializedSize(RowPosition, TypeSizes) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serializedSize(ColumnFamily, TypeSizes, int) - Static method in class org.apache.cassandra.db.SuperColumns
-
- serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serializedSize(WriteResponse, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serializedSize(AbstractBounds<?>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serializedSize(Token, TypeSizes) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serializedSize(EchoMessage, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serializedSize(Collection<Token>, TypeSizes) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- serializedSize(T, TypeSizes) - Method in interface org.apache.cassandra.io.ISerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
-
- serializedSize(RepairMessage, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serializedSize(SyncRequest, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serializedSize(ValidationRequest, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serializedSize(NodePair, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serializedSize(Collection<RowMutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serializedSize(Commit, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serializedSize(StreamRequest, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serializedSize(StreamSummary, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serializedSize() - Method in class org.apache.cassandra.transport.Event
-
- serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serializedSize(EstimatedHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serializedSize() - Method in interface org.apache.cassandra.utils.IFilter
-
- serializedSize(IntervalTree<C, D, I>, TypeSizes, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serializedSize(MerkleTree, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serializedSize() - Method in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- serializedSize(TypeSizes) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serializedSize(StreamingHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializedSizeForSSTable() - Method in class org.apache.cassandra.db.Column
-
- serializedSizeForSSTable() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- serializedSizeForSSTable() - Method in class org.apache.cassandra.db.RangeTombstone
-
- serializedValue - Variable in enum org.apache.cassandra.db.ReadCommand.Type
-
- serializedValueSize(Object) - Method in enum org.apache.cassandra.transport.DataType
-
- serializedValueSize(Object) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.SchemaChange
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.StatusChange
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.TopologyChange
-
- serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeForSSTable(OnDiskAtom, DataOutput) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- serializeForSSTable(RangeTombstone, DataOutput) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- serializeForSSTable(T, DataOutput) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Serialize the specified type into the specified DataOutputStream
instance in the format suited for SSTables.
- serializer - Static variable in class org.apache.cassandra.db.Column
-
- serializer - Static variable in class org.apache.cassandra.db.ColumnFamily
-
- serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- serializer - Static variable in class org.apache.cassandra.db.CounterMutation
-
- serializer() - Static method in class org.apache.cassandra.db.DeletionInfo
-
- serializer - Static variable in class org.apache.cassandra.db.DeletionTime
-
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- serializer - Static variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- serializer - Static variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- serializer - Variable in class org.apache.cassandra.db.marshal.ListType
-
- serializer - Static variable in class org.apache.cassandra.db.PagedRangeCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceReply
-
- serializer - Static variable in class org.apache.cassandra.db.RangeTombstone
-
- serializer - Static variable in class org.apache.cassandra.db.RangeTombstoneList
-
- serializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- serializer - Static variable in class org.apache.cassandra.db.ReadResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Row
-
- serializer - Static variable in class org.apache.cassandra.db.RowIndexEntry
-
- serializer - Static variable in class org.apache.cassandra.db.RowMutation
-
- serializer - Static variable in class org.apache.cassandra.db.RowPosition
-
- serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
-
- serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Truncation
-
- serializer - Static variable in class org.apache.cassandra.db.WriteResponse
-
- serializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
-
- serializer - Static variable in class org.apache.cassandra.dht.Token
-
- serializer - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- serializer - Static variable in class org.apache.cassandra.gms.EndpointState
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigest
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck2
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestSyn
-
- serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- serializer - Variable in class org.apache.cassandra.net.CallbackInfo
-
- serializer - Variable in class org.apache.cassandra.net.MessageOut
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.NodePair
-
- serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.FileMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- serializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamSummary
-
- serializer - Static variable in class org.apache.cassandra.utils.BooleanSerializer
-
- serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
-
- serializer(ISerializer<C>, ISerializer<D>, Constructor<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
-
- serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- serializer - Static variable in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
-
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializeSuperColumnFamily(ColumnFamily, DataOutput, int) - Static method in class org.apache.cassandra.db.SuperColumns
-
- SerializingCache<K,V> - Class in org.apache.cassandra.cache
-
Serializes cache values off-heap.
- SerializingCacheProvider - Class in org.apache.cassandra.cache
-
- SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
-
- serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
-
- serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- Server - Class in org.apache.cassandra.transport
-
- Server(InetSocketAddress) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(String, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(InetAddress, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server.ConnectionTracker - Class in org.apache.cassandra.transport
-
- Server.ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
-
- server_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- ServerConnection - Class in org.apache.cassandra.transport
-
- ServerConnection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
-
- ServerError - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- session - Variable in class org.apache.cassandra.repair.RepairFuture
-
- session - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- session - Variable in class org.apache.cassandra.streaming.StreamReader
-
- session - Variable in class org.apache.cassandra.streaming.StreamTask
-
StreamSession that this task belongs
- session - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SessionCompleteEventCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionCompleteEventCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- sessionFailed() - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.SESSION_FAILED
message.
- SessionFailedMessage - Class in org.apache.cassandra.streaming.messages
-
- SessionFailedMessage() - Constructor for class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
RepairSession id
- sessionId - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
-
- SessionInfo - Class in org.apache.cassandra.streaming
-
Stream session info.
- SessionInfo(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
-
- sessions - Variable in class org.apache.cassandra.streaming.StreamState
-
- SESSIONS_CF - Static variable in class org.apache.cassandra.tracing.Tracing
-
- sessionState - Static variable in class org.apache.cassandra.cli.CliMain
-
- SET - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SET - Static variable in class org.apache.cassandra.cli.CliParser
-
- set(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- set(double) - Method in class org.apache.cassandra.utils.DefaultDouble
-
- set(int) - Method in class org.apache.cassandra.utils.DefaultInteger
-
- set(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
Sets the bit at the specified index.
- set(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long, byte) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set_cql_version(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- set_or_map(Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setBound(ColumnIdentifier, Relation.Type, Term) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- setBoundVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setByte(long, byte) - 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
- setCacheCapacities(int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setCacheKeysToSave(int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setCallbackForTests(int, CallbackInfo) - Method in class org.apache.cassandra.net.MessagingService
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- setCapacity(long) - Method in interface org.apache.cassandra.cache.ICache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.SerializingCache
-
- setCasContentionTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCasContentionTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setCasContentionTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setColumnFamily(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
-
- setColumnsLimit(int) - Method in class org.apache.cassandra.cql.SelectExpression
-
- setColumnsReversed(boolean) - Method in class org.apache.cassandra.cql.SelectExpression
-
- setCompactionStrategyClass(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionStrategyClass(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction strategy by class name
- setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
Set the compaction threshold
- 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
-
- setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- setCompressionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompressionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set the compression parameters
- setCompressor(FrameCompressor) - Method in class org.apache.cassandra.transport.Connection
-
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
set hadoop cassandra connection settings
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set hadoop cassandra connection settings
- setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.cql.Attributes
-
- setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Allows user to resize core pool size of the thread pool.
- setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCQLVersion(String) - Method in class org.apache.cassandra.service.ClientState
-
- setCrcCheckChance(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCrcCheckChance(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set new crc check chance
- setCrcCheckChance(double) - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- setDataIntegrityWriter(DataIntegrityMetadata.ChecksumWriter) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Turn on digest computation on this writer.
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
-
- setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
-
- setDiskFailurePolicy(Config.DiskFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicBadnessThreshold(Double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicResetInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicUpdateInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- 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
-
- setIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- setIncrementalBackupsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- setIncrementalBackupsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setIndex(String, IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setIndexBuilt() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexBuilt(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setIndexRemoved() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexRemoved(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexType(IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setInMemoryCompactionLimit(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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.
- 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
-
- setInputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputRange(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, String, String, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputSlicePredicate(Configuration, SlicePredicate) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the predicate that determines what columns will be selected from each row.
- setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the size of the input split.
- setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL user defined where clauses for the input of this job.
- setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.WhereClause
-
- setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeySpace(String) - Method in class org.apache.cassandra.cli.CliClient
-
- setKeyspace(String) - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- setKeyspace(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
-
- setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
-
- setKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Update (or insert) new keyspace definition
- setKeyType(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set read configuration settings
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
set read configuration settings
- setLog4jLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- setLog4jLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
set the logging level at runtime
- setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- 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
-
Deprecated.
Allows user to resize maximum size of the thread pool.
- setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the validator thread pool.
- setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setMinimumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setMinimumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the minimum number of sstables in queue before compaction kicks off
- setMultiKey(boolean) - Method in class org.apache.cassandra.cql.WhereClause
-
- 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.TFramedTransportFactory
-
- setOrdering(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- setOutboundBindAny(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL prepared statement for the output of this job.
- setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace for the output of this job.
- setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setPartitioner(IPartitioner<?>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPartitioner(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set partition filter
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
- setPendingRanges(String, Multimap<Range<Token>, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- setRangeRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRangeRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRangeRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setReadConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setReadRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setReadRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setReadRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- 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
-
- setRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- Sets - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for sets.
- Sets.Adder - Class in org.apache.cassandra.cql3
-
- Sets.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
-
- Sets.DelayedValue - Class in org.apache.cassandra.cql3
-
- Sets.DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
-
- Sets.Discarder - Class in org.apache.cassandra.cql3
-
- Sets.Discarder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
-
- Sets.Literal - Class in org.apache.cassandra.cql3
-
- Sets.Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Sets.Literal
-
- Sets.Marker - Class in org.apache.cassandra.cql3
-
- Sets.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
-
- Sets.Setter - Class in org.apache.cassandra.cql3
-
- Sets.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
-
- Sets.Value - Class in org.apache.cassandra.cql3
-
- Sets.Value(Set<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
-
- SetSerializer<T> - Class in org.apache.cassandra.serializers
-
- setSeverity(double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- setSeverity(double) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
Use this if you want to specify a severity; it can be negative
Example: Page cache is cold and you want data to be sent
though it is not preferred one.
- setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- setStart(ByteBuffer) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- setStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
StoreFunc methods
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set store configuration settings
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
set store configuration settings
- setStreamId(int) - Method in class org.apache.cassandra.transport.Message
-
- setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- setThriftFramedTransportSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Sets the socket timeout
- setTimestamp(Long) - Method in class org.apache.cassandra.cql.Attributes
-
- setTimeToLive(int) - Method in class org.apache.cassandra.cql.Attributes
-
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- setTraceProbability() - Method in class org.apache.cassandra.cli.CliParser
-
- setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
-
- setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Enables/Disables tracing for the whole system.
- setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
-
- setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- setTrackedBy(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- setTracker(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- setTreeAdaptor(TreeAdaptor) - Method in class org.apache.cassandra.cli.CliParser
-
- setTruncateRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTruncateRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setTruncateRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setTupleValue(Tuple, int, Object) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
set the value to the position of the tuple
- SetType<T> - Class in org.apache.cassandra.db.marshal
-
- SetType(AbstractType<T>) - Constructor for class org.apache.cassandra.db.marshal.SetType
-
- setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- setup() - Static method in class org.apache.cassandra.auth.Auth
-
Sets up Authenticator and Authorizer.
- setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Setup is called once upon system startup to initialize the IAuthorizer.
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- setup() - Method in class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
-
- setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
-
- setValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setVersion(InetAddress, int) - Method in class org.apache.cassandra.net.MessagingService
-
- setWriteConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setWriteRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- shouldHint() - Method in class org.apache.cassandra.net.CallbackInfo
-
- shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
-
- shouldInclude(SSTableReader) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- shouldInclude(InetAddress) - Method in interface org.apache.cassandra.dht.RangeStreamer.ISourceFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- shouldPreheatPageCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- shouldPurge(DecoratedKey, long) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- shouldPurge(DecoratedKey, long) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- shouldReplicateOnWrite() - Method in class org.apache.cassandra.db.CounterMutation
-
- SHOW - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SHOW - Static variable in class org.apache.cassandra.cli.CliParser
-
- showClusterName() - Method in class org.apache.cassandra.cli.CliParser
-
- showKeyspaces() - Method in class org.apache.cassandra.cli.CliParser
-
- showSchema() - Method in class org.apache.cassandra.cli.CliParser
-
- showStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- showVersion() - Method in class org.apache.cassandra.cli.CliParser
-
- Shuffle - Class in org.apache.cassandra.tools
-
- Shuffle(String, int) - Constructor for class org.apache.cassandra.tools.Shuffle
-
- Shuffle(String, int, String, int, boolean, String, String) - Constructor for class org.apache.cassandra.tools.Shuffle
-
- shuffle(boolean, String) - Method in class org.apache.cassandra.tools.Shuffle
-
Create and distribute a new, randomized token to endpoint mapping.
- shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Initiates the shutdown process for the allocator thread.
- shutdown() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
shuts down the CommitLogExecutor in an orderly fashion
- 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.LeveledCompactionStrategy
-
- 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)
- shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Shuts down the threads used by the commit log, blocking until completion.
- shutdownBlocking() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
-
This method shuts down all registered stages.
- shutdownNow() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- signal() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- signalAll() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- SimpleAbstractColumnIterator - Class in org.apache.cassandra.db.columniterator
-
- SimpleAbstractColumnIterator() - Constructor for class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
-
- SimpleClient - Class in org.apache.cassandra.transport
-
- SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleCondition - Class in org.apache.cassandra.utils
-
- SimpleCondition() - Constructor for class org.apache.cassandra.utils.SimpleCondition
-
- SimpleSeedProvider - Class in org.apache.cassandra.locator
-
- SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
-
- SimpleSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that treats Strategy order as proximity,
allowing non-read-repaired reads to prefer a single endpoint, which improves
cache locality.
- SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
-
- 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
-
- SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
-
- SinglePartitionPager - Interface in org.apache.cassandra.service.pager
-
Common interface to single partition queries (by slice and by name).
- SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliParser
-
- singleton(T) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- SinkManager - Class in org.apache.cassandra.net.sink
-
- SinkManager() - Constructor for class org.apache.cassandra.net.sink.SinkManager
-
- size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- size() - Method in interface org.apache.cassandra.cache.ICache
-
- size() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- size() - Method in class org.apache.cassandra.cache.SerializingCache
-
- size() - Method in class org.apache.cassandra.cql3.ResultSet
-
- size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- size() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- size() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- size() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the total number of bytes written to this stream so far.
- size() - Method in class org.apache.cassandra.io.util.Memory
-
- size - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total size of cache, in bytes
- size - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
-
Total size of file cache, in bytes
- size() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- size() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- size() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- size() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- size - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- size() - Method in class org.apache.cassandra.utils.MerkleTree
-
The number of distinct ranges contained in this tree.
- size() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity of this set.
- sizeInBytes() - Method in class org.apache.cassandra.service.FileCacheService
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(String) - Method in class org.apache.cassandra.db.TypeSizes
-
assumes UTF8
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfEnumValue(T) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfInet(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfLongString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringList(List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringMap(Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringToStringListMap(Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeofVInt(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeofWithLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithShortLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- sizeOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- skip(DataInput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Skips count
number of bytes in this InputStream.
- skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- skipBytesFully(DataInput, long) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- skipIndex(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
Skip the index
- skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- SkipNullRepresenter - Class in org.apache.cassandra.utils
-
- SkipNullRepresenter() - Constructor for class org.apache.cassandra.utils.SkipNullRepresenter
-
- skipPromotedIndex(DataInput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skipShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SlabAllocator - Class in org.apache.cassandra.utils
-
The SlabAllocator is a bump-the-pointer allocator that allocates
large (2MB by default) regions and then doles them out to threads that request
slices into the array.
- SlabAllocator() - Constructor for class org.apache.cassandra.utils.SlabAllocator
-
- SliceByNamesReadCommand - Class in org.apache.cassandra.db
-
- SliceByNamesReadCommand(String, ByteBuffer, String, long, NamesQueryFilter) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
-
- sliceFilterToSC(CompositeType, SliceQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- SliceFromReadCommand - Class in org.apache.cassandra.db
-
- SliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
-
- SliceQueryFilter - Class in org.apache.cassandra.db.filter
-
- SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ColumnSlice[], boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
Constructor that accepts multiple slices.
- SliceQueryFilter(ColumnSlice[], boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- SliceQueryFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- SliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pager over a SliceFromReadCommand.
- slices - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- 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, 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_before_compaction - Variable in class org.apache.cassandra.config.Config
-
- snapshot_name - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- SNAPSHOT_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
-
- SnapshotCommand - Class in org.apache.cassandra.db
-
- SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
-
- snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
-
- 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.
- snapshotLeveledManifest(String) - Method in class org.apache.cassandra.db.Directories
-
Deprecated.
- snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SnapshotVerbHandler - Class in org.apache.cassandra.service
-
- SnapshotVerbHandler() - Constructor for class org.apache.cassandra.service.SnapshotVerbHandler
-
- snapshotWithoutCFS(String, String) - Static method in class org.apache.cassandra.db.compaction.LegacyLeveledManifest
-
Deprecated.
Snapshot a CF without having to load the sstables in that directory
- snapshotWithoutFlush(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- SNITCH_PROPERTIES_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
-
- SnitchProperties - Class in org.apache.cassandra.locator
-
- SnitchProperties() - Constructor for class org.apache.cassandra.locator.SnitchProperties
-
- socket - Variable in class org.apache.cassandra.transport.Server
-
- SOFTIRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the List of node addresses, in-place, by proximity to the given address
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
This method will sort the List by proximity to the given address.
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- SortedBiMultiValMap<K,V> - Class in org.apache.cassandra.utils
-
- SortedBiMultiValMap(SortedMap<K, V>, SortedSetMultimap<V, K>) - Constructor for class org.apache.cassandra.utils.SortedBiMultiValMap
-
- sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- spaceReclaimed(long) - Method in class org.apache.cassandra.db.DataTracker
-
- SPEC - Static variable in class org.apache.cassandra.utils.ObjectSizes
-
- speculativeRetry(CFMetaData.SpeculativeRetry) - Method in class org.apache.cassandra.config.CFMetaData
-
- speculativeRetry - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
-
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Split a composite column names into it's components.
- split(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?),
where ? means that the same type of AbstractBounds is returned as the original.
- split(T) - Method in class org.apache.cassandra.dht.Bounds
-
- split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.Range
-
- split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Splits the range containing the given token, if no tree limits would be
violated.
- splitSize - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ssl_storage_port - Variable in class org.apache.cassandra.config.Config
-
- SSLFactory - Class in org.apache.cassandra.security
-
A Factory for providing and setting up Client and Server SSL wrapped
Socket and ServerSocket
- SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
-
- SSLTransportFactory - Class in org.apache.cassandra.cli.transport
-
- SSLTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.SSLTransportFactory
-
- sstable - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- SSTable - Class in org.apache.cassandra.io.sstable
-
This class is built on top of the SequenceFile.
- SSTable(Descriptor, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- SSTable(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- sstable - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.FileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- SSTableAddedNotification - Class in org.apache.cassandra.notifications
-
- SSTableAddedNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
-
- sstableComparator - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- sstableCompressor - Variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- SSTableDeletingNotification - Class in org.apache.cassandra.notifications
-
Fired right before removing an SSTable.
- SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- SSTableDeletingTask - Class in org.apache.cassandra.io.sstable
-
- SSTableDeletingTask(SSTableReader) - Constructor for class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- SSTableExport - Class in org.apache.cassandra.tools
-
Export SSTables to JSON format.
- SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
-
- SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableImport - Class in org.apache.cassandra.tools
-
Create SSTables from JSON input
- SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(boolean, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(Integer, boolean, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- 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(Iterable<SSTableReader>, Iterable<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- sstableLister() - 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.Client - Class in org.apache.cassandra.io.sstable
-
- SSTableLoader.Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- SSTableMetadata - Class in org.apache.cassandra.io.sstable
-
Metadata for a SSTable.
- SSTableMetadata.Collector - Class in org.apache.cassandra.io.sstable
-
- SSTableMetadata.SSTableMetadataSerializer - Class in org.apache.cassandra.io.sstable
-
- SSTableMetadata.SSTableMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- SSTableMetadataViewer - Class in org.apache.cassandra.tools
-
Shows the contents of sstable metadata
- SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
-
- SSTableNamesIterator - Class in org.apache.cassandra.db.columniterator
-
- SSTableNamesIterator(SSTableReader, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- SSTableNamesIterator(SSTableReader, FileDataInput, DecoratedKey, SortedSet<ByteBuffer>, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- SSTableReader - Class in org.apache.cassandra.io.sstable
-
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.
- SSTableReader.EmptyCompactionScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableReader.EmptyCompactionScanner(String) - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- SSTableReader.Operator - Class in org.apache.cassandra.io.sstable
-
TODO: Move someplace reusable
- SSTableReader.Operator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- SSTableReader.SizeComparator - Class in org.apache.cassandra.io.sstable
-
- SSTableReader.SizeComparator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.SizeComparator
-
- sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- sstables - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
-
- SSTableScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
-
- SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that doesn't assume rows are in sorted order.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Create a new buffering writer.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that assumes rows are in (partitioner) sorted order.
- SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Create a new writer.
- SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- SSTableSliceIterator - Class in org.apache.cassandra.db.columniterator
-
A Column Iterator over SSTable
- SSTableSliceIterator(SSTableReader, DecoratedKey, ColumnSlice[], boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
An iterator for a slice within an SSTable
- sstablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Histogram of the number of sstable data files accessed per read
- SSTableSplitter - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
-
- SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplitController(ColumnFamilyStore, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplittingCompactionTask(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- sstablesRewrite(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SSTableWriter - Class in org.apache.cassandra.io.sstable
-
- SSTableWriter(String, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- SSTableWriter(String, long, CFMetaData, IPartitioner<?>, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- Stage - Enum in org.apache.cassandra.concurrent
-
- StageManager - Class in org.apache.cassandra.concurrent
-
This class manages executor services for Messages recieved: each Message requests
running on a specific "stage" for concurrency control; hence the Map approach,
even though stages (executors) are not created dynamically.
- StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
-
- StandaloneScrubber - Class in org.apache.cassandra.tools
-
- StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
-
- StandaloneSplitter - Class in org.apache.cassandra.tools
-
- StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
-
- StandaloneUpgrader - Class in org.apache.cassandra.tools
-
- StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
-
- start() - Method in class org.apache.cassandra.db.BatchlogManager
-
- start - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- start() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- start() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- start - Variable in class org.apache.cassandra.db.PagedRangeCommand
-
- start(int) - Method in class org.apache.cassandra.gms.Gossiper
-
- start(int, Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.Gossiper
-
Start the gossiper with the generation number, preloading the map of application states before starting
- start() - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- start - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Start the server.
- start() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
-
- start() - Method in class org.apache.cassandra.service.GCInspector
-
- 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_native_transport - Variable in class org.apache.cassandra.config.Config
-
- start_rpc - Variable in class org.apache.cassandra.config.Config
-
- startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- startCompaction(ColumnFamilyStore, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Write compaction log, except columfamilies under system keyspace.
- started() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
report event on the size of the compaction.
- startGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startKey() - Method in class org.apache.cassandra.db.DataRange
-
- startNativeTransport() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- startNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startOf(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- startRpc() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- StartupMessage - Class in org.apache.cassandra.transport.messages
-
The initial message of the protocol.
- StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
-
- state() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- state() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Get the current state of the pager.
- state() - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- state() - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- state() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- state - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Current session state
- state(StreamSession.State) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set current state to newState
.
- state() - Method in class org.apache.cassandra.streaming.StreamSession
-
- state() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- statement() - Method in class org.apache.cassandra.cli.CliParser
-
- statement - Variable in class org.apache.cassandra.cql.CQLStatement
-
- statement - Variable in class org.apache.cassandra.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
-
- statements - Variable in class org.apache.cassandra.cql.BatchStatement
-
- StatementType - Enum in org.apache.cassandra.cql
-
- STATS - Static variable in class org.apache.cassandra.io.sstable.Component
-
- status - Variable in class org.apache.cassandra.transport.Event.StatusChange
-
- STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_RELOCATING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- StatusLogger - Class in org.apache.cassandra.utils
-
- StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
-
- stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- stop - Variable in class org.apache.cassandra.db.PagedRangeCommand
-
- stop() - Method in class org.apache.cassandra.gms.Gossiper
-
- stop() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Stop the client.
- stop() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Stop the server.
- stop() - Method in class org.apache.cassandra.service.CassandraDaemon
-
Stop the daemon, ideally in an idempotent manner.
- stop(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- stop() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- stop() - Method in class org.apache.cassandra.transport.Server
-
- 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
.
- stopGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopKey() - Method in class org.apache.cassandra.db.DataRange
-
- stopNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopNonLocal(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopSession() - Method in class org.apache.cassandra.tracing.Tracing
-
Stop the session and record its complete.
- stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- storage_port - Variable in class org.apache.cassandra.config.Config
-
- StorageMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Storage.
- StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
-
- StorageProxy - Class in org.apache.cassandra.service
-
- StorageProxy.WritePerformer - Interface in org.apache.cassandra.service
-
- StorageProxyMBean - Interface in org.apache.cassandra.service
-
- StorageService - Class in org.apache.cassandra.service
-
This abstraction contains the token/identifier of this node
on the identifier space.
- StorageService() - Constructor for class org.apache.cassandra.service.StorageService
-
- StorageServiceMBean - Interface in org.apache.cassandra.service
-
- store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- storeKeyspaceInstance(Keyspace) - Method in class org.apache.cassandra.config.Schema
-
Store given Keyspace instance to the schema
- storeSignature - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- strategyClass - Variable in class org.apache.cassandra.config.KSMetaData
-
- strategyOptions - Variable in class org.apache.cassandra.config.KSMetaData
-
- stream() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream(Set<InetAddress>) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- 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.ProgressEvent(UUID, ProgressInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
-
- StreamEvent.SessionCompleteEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionCompleteEvent(StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- StreamEvent.SessionPreparedEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionPreparedEvent(UUID, SessionInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- 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 - Class in org.apache.cassandra.streaming
-
- StreamException(StreamState, String) - Constructor for class org.apache.cassandra.streaming.StreamException
-
- StreamException(StreamState, String, Throwable) - Constructor for class org.apache.cassandra.streaming.StreamException
-
- streamId - Variable in class org.apache.cassandra.transport.Frame.Header
-
- streaming_socket_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- StreamingHistogram - Class in org.apache.cassandra.utils
-
Histogram that can be constructed from streaming of data.
- StreamingHistogram(int) - Constructor for class org.apache.cassandra.utils.StreamingHistogram
-
Creates a new histogram with max bin size of maxBinSize
- StreamingHistogram.StreamingHistogramSerializer - Class in org.apache.cassandra.utils
-
- StreamingHistogram.StreamingHistogramSerializer() - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- StreamingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for streaming.
- StreamingMetrics(InetAddress) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
-
- StreamingRepairTask - Class in org.apache.cassandra.repair
-
Task that make two nodes exchange (stream) some ranges (for a given table/cf).
- StreamingRepairTask(RepairJobDesc, SyncRequest) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
-
- StreamInitMessage - Class in org.apache.cassandra.streaming.messages
-
StreamInitMessage is first sent from the node where
StreamSession
is started,
to initiate corresponding
StreamSession
on the other side.
- StreamInitMessage(InetAddress, UUID, String, 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
-
- 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.
- StreamReader - Class in org.apache.cassandra.streaming
-
StreamReader reads from stream and writes to SSTable.
- StreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamReader
-
- StreamReceiveTask - Class in org.apache.cassandra.streaming
-
Task that manages receiving files for the session for certain ColumnFamily.
- StreamReceiveTask(StreamSession, UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
-
- StreamRequest - Class in org.apache.cassandra.streaming
-
- StreamRequest(String, Collection<Range<Token>>, Collection<String>) - Constructor for class org.apache.cassandra.streaming.StreamRequest
-
- StreamRequest.StreamRequestSerializer - Class in org.apache.cassandra.streaming
-
- StreamRequest.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) - Constructor for class org.apache.cassandra.streaming.StreamSession
-
Create new streaming session with the peer.
- StreamSession.SSTableStreamingSections - Class in org.apache.cassandra.streaming
-
- StreamSession.SSTableStreamingSections(SSTableReader, List<Pair<Long, Long>>, long) - Constructor for class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- StreamSession.State - Enum in org.apache.cassandra.streaming
-
- StreamState - Class in org.apache.cassandra.streaming
-
Current snapshot of streaming progress.
- StreamState(UUID, String, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
-
- StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- StreamSummary - Class in org.apache.cassandra.streaming
-
Summary of streaming.
- StreamSummary(UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamSummary
-
- StreamSummary.StreamSummarySerializer - Class in org.apache.cassandra.streaming
-
- StreamSummary.StreamSummarySerializer() - Constructor for class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- StreamSummaryCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamSummaryCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- StreamTask - Class in org.apache.cassandra.streaming
-
StreamTask is an abstraction of the streaming task performed over specific ColumnFamily.
- StreamTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTask
-
- StreamTransferTask - Class in org.apache.cassandra.streaming
-
StreamTransferTask sends sections of SSTable files in certain ColumnFamily.
- StreamTransferTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
-
- StreamWriter - Class in org.apache.cassandra.streaming
-
StreamWriter writes given section of the SSTable to given channel.
- StreamWriter(SSTableReader, Collection<Pair<Long, Long>>, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamWriter
-
- string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlParser
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyCollectionsParameters(Map<ByteBuffer, 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.
- StringLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- StringLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- StringToken - Class in org.apache.cassandra.dht
-
- StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
-
- subcodec - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- submit(Callable<T>) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
- submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Call this whenever a compaction might be needed on the given columnfamily.
- submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitDifferencers() - Method in class org.apache.cassandra.repair.RepairJob
-
Submit differencers for running.
- submitHint(RowMutation, InetAddress, AbstractWriteResponseHandler, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Is not scheduled, because it is performing disjoint work from sstable compaction.
- submitMaximal(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitRepairSession(Range<Token>, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Requests repairs for the given keyspace and column families.
- submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitValidation(ColumnFamilyStore, Validator) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Does not mutate data, so is not scheduled.
- submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- subName(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.DataTracker
-
- subscribers - Variable in class org.apache.cassandra.db.DataTracker
-
- subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- success - Variable in class org.apache.cassandra.db.TruncateResponse
-
- success - Variable in class org.apache.cassandra.repair.messages.SyncComplete
-
true if sync success, false otherwise
- success - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
true if validation success, false otherwise
- success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- sum() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
-
Calculates estimated number of points in interval [-inf,b].
- 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
-
- superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- SuperColumns - Class in org.apache.cassandra.db
-
- SuperColumns() - Constructor for class org.apache.cassandra.db.SuperColumns
-
- SuperColumns.SCFilter - Class in org.apache.cassandra.db
-
- SuperColumns.SCFilter(ByteBuffer, IDiskAtomFilter) - Constructor for class org.apache.cassandra.db.SuperColumns.SCFilter
-
- supersedes(RangeTombstone, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.RangeTombstone
-
This tombstone supersedes another one if it is more recent and cover a
bigger range than rt.
- SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.Auth
-
- supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- SupportedMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
-
- supportedOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- supportedOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Set of options supported by CREATE USER and ALTER USER queries.
- supportedOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- switchLock - Static variable in class org.apache.cassandra.db.Keyspace
-
accesses to CFS.memtable should acquire this for thread safety.
- switchMemtable(boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Switch and flush the current memtable, if it was dirty.
- switchMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
Switch the current memtable.
- sync() - 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.db.commitlog.CommitLogSegment
-
Forces a disk flush for this segment file.
- sync() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- sync() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Synchronize file contents with disk.
- SYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer
-
- SyncComplete - Class in org.apache.cassandra.repair.messages
-
- SyncComplete(RepairJobDesc, NodePair, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- SyncComplete(RepairJobDesc, InetAddress, InetAddress, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- syncComplete(RepairJobDesc, NodePair, boolean) - Method in class org.apache.cassandra.repair.RepairSession
-
Notify this session that sync completed/failed with given NodePair
.
- syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncNeeded - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- SyncRequest - Class in org.apache.cassandra.repair.messages
-
Body part of SYNC_REQUEST repair message.
- SyncRequest(RepairJobDesc, InetAddress, InetAddress, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
-
- SyncRequest.SyncRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- SyncRequest.SyncRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- SyntaxException - Exception in org.apache.cassandra.exceptions
-
- SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
-
- SYS_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- system() - Static method in class org.apache.cassandra.db.Keyspace
-
- system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- SYSTEM_KS - Static variable in class org.apache.cassandra.db.Keyspace
-
- system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
update an existing keyspace, but do not allow column family modifications.
- systemKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
-
- SystemKeyspace - Class in org.apache.cassandra.db
-
- SystemKeyspace() - Constructor for class org.apache.cassandra.db.SystemKeyspace
-
- SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
-
- systemKeyspaceNames - Static variable in class org.apache.cassandra.config.Schema
-
- T - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- t - Variable in class org.apache.cassandra.cql3.Operation
-
- T__100 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__100 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__101 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__101 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__102 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__102 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__103 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__103 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__104 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__104 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__105 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__105 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__106 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__106 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__107 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__107 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__111 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__111 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__112 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__112 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__113 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__113 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__114 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__114 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__115 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__115 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__116 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__116 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__117 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__117 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__118 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__118 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__119 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__119 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__120 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__120 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__121 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__121 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__122 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__122 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__123 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__123 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__124 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__124 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__125 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__125 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__126 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__126 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__127 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__127 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__128 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__128 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__129 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__129 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__130 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__130 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__131 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__131 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__132 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__132 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__133 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__133 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__134 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__134 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__135 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__135 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__136 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__136 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__137 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__137 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__138 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__138 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__139 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__139 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__140 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__140 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__141 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__141 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__142 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__142 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__143 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__143 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__144 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__144 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__145 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__145 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__146 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__146 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__147 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__147 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__148 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__148 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__149 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__149 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__150 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__150 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__81 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__81 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__82 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__82 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__83 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__83 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__84 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__84 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__85 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__85 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__86 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__86 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__87 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__87 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__88 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__88 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__89 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__89 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__90 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__90 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__91 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__91 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__92 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__92 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__93 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__93 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__94 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__94 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__95 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__95 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__96 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__96 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__97 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__97 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__98 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__98 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__99 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__99 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- table - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- takeColumnFamilySnapshot(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot of a specific column family.
- takeColumnFamilySnapshot(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Takes the snapshot of a specific column family.
- takeSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Takes the snapshot for the given keyspaces.
- takeSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Takes the snapshot for the given keyspaces.
- takeSnapshot(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Take a snapshot of all the keyspaces, optionally specifying only a specific column family.
- target - Variable in class org.apache.cassandra.net.CallbackInfo
-
- targets - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- TASK_ID - Static variable in class org.apache.cassandra.net.HeaderTypes
-
- TASK_PROFILE_CHAIN - Static variable in class org.apache.cassandra.net.HeaderTypes
-
- taskCompleted(StreamReceiveTask) - Method in class org.apache.cassandra.streaming.StreamSession
-
- taskCompleted(StreamTransferTask) - Method in class org.apache.cassandra.streaming.StreamSession
-
- tasks - Static variable in class org.apache.cassandra.service.StorageService
-
This pool is used by tasks that can have longer execution times, and usually are non periodic.
- 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) - 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.
- tearDown() - Method in class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
-
- TEMPFILE_MARKER - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- temporary - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- term() - Method in class org.apache.cassandra.cql.CqlParser
-
- Term - Class in org.apache.cassandra.cql
-
A term parsed from a CQL statement.
- Term(String, TermType) - Constructor for class org.apache.cassandra.cql.Term
-
- Term(String, int) - Constructor for class org.apache.cassandra.cql.Term
-
Create new Term instance from a string, and an integer that corresponds
with the token ID from CQLParser.
- Term(long, TermType) - Constructor for class org.apache.cassandra.cql.Term
-
- Term() - Constructor for class org.apache.cassandra.cql.Term
-
- Term(String, int, int) - Constructor for class org.apache.cassandra.cql.Term
-
- term() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Term - Interface in org.apache.cassandra.cql3
-
A CQL3 term, i.e.
- Term.NonTerminal - Class in org.apache.cassandra.cql3
-
A non terminal term, i.e.
- Term.NonTerminal() - Constructor for class org.apache.cassandra.cql3.Term.NonTerminal
-
- Term.Raw - Interface in org.apache.cassandra.cql3
-
A parsed, non prepared (thus untyped) term.
- Term.Terminal - Class in org.apache.cassandra.cql3
-
A terminal term, one that can be reduced to a byte buffer directly.
- Term.Terminal() - Constructor for class org.apache.cassandra.cql3.Term.Terminal
-
- terminate() - Method in class org.apache.cassandra.repair.RepairJob
-
terminate this job.
- terminate() - Method in class org.apache.cassandra.repair.RepairSession
-
- terminateSessions() - Method in class org.apache.cassandra.service.ActiveRepairService
-
- termList() - Method in class org.apache.cassandra.cql.CqlParser
-
- termPair(Map<Term, Term>) - Method in class org.apache.cassandra.cql.CqlParser
-
- termPairWithOperation(Map<Term, Operation>) - Method in class org.apache.cassandra.cql.CqlParser
-
- testMetadata(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- testMetadataNotDurable(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- TFramedTransportFactory - Class in org.apache.cassandra.thrift
-
- TFramedTransportFactory() - Constructor for class org.apache.cassandra.thrift.TFramedTransportFactory
-
- threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- threadLocalRandom() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ThreadPoolMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ThreadPoolExecutor
.
- ThreadPoolMetrics(ThreadPoolExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Create metrics for given ThreadPoolExecutor.
- thrift_framed_transport_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- thrift_max_message_length_in_mb - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- ThriftClientState - Class in org.apache.cassandra.thrift
-
ClientState used by thrift that also provide a QueryState.
- ThriftClientState() - Constructor for class org.apache.cassandra.thrift.ThriftClientState
-
- ThriftConversion - Class in org.apache.cassandra.thrift
-
Static utility methods to convert internal structure to and from thrift ones.
- ThriftConversion() - Constructor for class org.apache.cassandra.thrift.ThriftConversion
-
- thriftifyColumns(Collection<Column>, boolean, long) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
-
- thriftServer - Variable in class org.apache.cassandra.service.CassandraDaemon
-
- ThriftServer - Class in org.apache.cassandra.thrift
-
- ThriftServer(InetAddress, int) - Constructor for class org.apache.cassandra.thrift.ThriftServer
-
- ThriftSessionManager - Class in org.apache.cassandra.thrift
-
Encapsulates the current client state (session).
- ThriftSessionManager() - Constructor for class org.apache.cassandra.thrift.ThriftSessionManager
-
- ThriftValidation - Class in org.apache.cassandra.thrift
-
This has a lot of building blocks for CassandraServer to call to make sure it has valid input
-- ensuring column names conform to the declared comparator, for instance.
- ThriftValidation() - Constructor for class org.apache.cassandra.thrift.ThriftValidation
-
- throttle_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- ThrottledReader - Class in org.apache.cassandra.io.util
-
- ThrottledReader(File, RateLimiter) - Constructor for class org.apache.cassandra.io.util.ThrottledReader
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlLexer
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlParser
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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
-
- THsHaDisruptorServer.Factory() - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer.Factory
-
- TICK_CYCLE_TIME - Static variable in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
The (theoretical) max milliseconds between loop runs to perform janitorial tasks
- timeout - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- timeouts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- timeouts - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Number of timeouts for specific IP
- timestamp - Variable in class org.apache.cassandra.cql.AbstractModification
-
- timestamp - Variable in class org.apache.cassandra.cql.BatchStatement
-
- timestamp - Variable in class org.apache.cassandra.cql3.Attributes.Raw
-
- timestamp - Variable in class org.apache.cassandra.cql3.UpdateParameters
-
- timestamp - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- timestamp - Variable in class org.apache.cassandra.db.Column
-
- timestamp() - Method in class org.apache.cassandra.db.Column
-
- timestamp - Variable in class org.apache.cassandra.db.filter.ColumnCounter
-
- timestamp - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
-
- timestamp - Variable in class org.apache.cassandra.db.filter.QueryFilter
-
- timestamp - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- timestamp - Variable in class org.apache.cassandra.db.ReadCommand
-
- timestamp() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- timestamp - Variable in class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- timestampOfLastDelete() - Method in class org.apache.cassandra.db.CounterColumn
-
- TimestampSerializer - Class in org.apache.cassandra.serializers
-
- TimestampSerializer() - Constructor for class org.apache.cassandra.serializers.TimestampSerializer
-
- TimestampType - Class in org.apache.cassandra.db.marshal
-
Type for date-time values.
- timeToLive - Variable in class org.apache.cassandra.cql.AbstractModification
-
- timeToLive - Variable in class org.apache.cassandra.cql.BatchStatement
-
- timeToLive - Variable in class org.apache.cassandra.cql3.Attributes.Raw
-
- TimeuuidFcts - Class in org.apache.cassandra.cql3.functions
-
- TimeuuidFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- TimeUUIDSerializer - Class in org.apache.cassandra.serializers
-
- TimeUUIDSerializer() - Constructor for class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- TimeUUIDType - Class in org.apache.cassandra.db.marshal
-
- toByteArray(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- toByteArray() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a byte array.
- toBytes() - Method in class org.apache.cassandra.db.ColumnFamily
-
- TOC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- toCompositeData(UUID, ProgressInfo) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- toCompositeData(StreamEvent.SessionCompleteEvent) - Static method in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- toCompositeData(UUID, SessionInfo) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- toCompositeData(StreamState) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- toCompositeData(StreamSummary) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- toInt(String, String, Integer) - Static method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to an integer.
- token - Variable in class org.apache.cassandra.db.DecoratedKey
-
- Token<T> - Class in org.apache.cassandra.dht
-
- Token(T) - Constructor for class org.apache.cassandra.dht.Token
-
- token - Variable in class org.apache.cassandra.dht.Token
-
- token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- Token.KeyBound - Class in org.apache.cassandra.dht
-
- Token.TokenFactory<T> - Class in org.apache.cassandra.dht
-
- Token.TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
-
- Token.TokenSerializer - Class in org.apache.cassandra.dht
-
- Token.TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
-
- TokenFct - Class in org.apache.cassandra.cql3.functions
-
- TokenFct(CFMetaData) - Constructor for class org.apache.cassandra.cql3.functions.TokenFct
-
- tokenMetadata - Variable in class org.apache.cassandra.dht.BootStrapper
-
- TokenMetadata - Class in org.apache.cassandra.locator
-
- TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
-
- TokenMetadata.Topology - Class in org.apache.cassandra.locator
-
Tracks the assignment of racks and endpoints in each datacenter for all the "normal" endpoints
in this TokenMetadata.
- TokenMetadata.Topology() - Constructor for class org.apache.cassandra.locator.TokenMetadata.Topology
-
- TokenMetadata.Topology(TokenMetadata.Topology) - Constructor for class org.apache.cassandra.locator.TokenMetadata.Topology
-
construct deep-copy of other
- tokenNames - Static variable in class org.apache.cassandra.cli.CliParser
-
- tokenNames - Static variable in class org.apache.cassandra.cql.CqlParser
-
- tokenNames - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- tokens - Variable in class org.apache.cassandra.dht.BootStrapper
-
- tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- TokenSerializer - Class in org.apache.cassandra.gms
-
- TokenSerializer() - Constructor for class org.apache.cassandra.gms.TokenSerializer
-
- tokensFromString(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- TOMBSTONE_COMPACTION_INTERVAL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- TOMBSTONE_HISTOGRAM_BIN_SIZE - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- TOMBSTONE_THRESHOLD_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstoneCompactionInterval - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstoneHistogram - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
histogram of tombstone drop time
- tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- tombstoneTracker() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
-
- topology - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- toRowBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
-
Transform this abstract bounds to equivalent covering bounds of row positions.
- toRowBounds() - Method in class org.apache.cassandra.dht.Bounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.Range
-
- toSchema(RowMutation, long) - Method in class org.apache.cassandra.config.CFMetaData
-
- toSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
-
Convert current metadata into schema mutation
- toSchema(RowMutation, String, AbstractType<?>, long) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
-
- toSchema(RowMutation, String, long) - Method in class org.apache.cassandra.config.TriggerDefinition
-
Add specified trigger to the schema using given row.
- toSchemaUpdate(CFMetaData, long, boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
Create schema mutations to update this metadata to provided new state.
- toSchemaUpdate(KSMetaData, long) - Method in class org.apache.cassandra.config.KSMetaData
-
- toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- toString() - Method in class org.apache.cassandra.auth.DataResource
-
- toString() - Method in class org.apache.cassandra.auth.PermissionDetails
-
- toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
-
Deprecated.
- toString() - Method in class org.apache.cassandra.cache.KeyCacheKey
-
- toString() - Method in class org.apache.cassandra.cache.RowCacheKey
-
- toString() - Method in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- toString() - Method in class org.apache.cassandra.config.CFMetaData
-
- toString() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toString() - Method in class org.apache.cassandra.config.KSMetaData
-
- toString() - Method in class org.apache.cassandra.config.TriggerDefinition
-
- toString() - Method in class org.apache.cassandra.cql.AlterTableStatement
-
- toString() - Method in class org.apache.cassandra.cql.Attributes
-
- toString() - Method in class org.apache.cassandra.cql.BatchStatement
-
- toString() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- toString() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- toString() - Method in class org.apache.cassandra.cql.Operation
-
- toString() - Method in class org.apache.cassandra.cql.Relation
-
- toString() - Method in class org.apache.cassandra.cql.SelectExpression
-
- toString() - Method in class org.apache.cassandra.cql.SelectStatement
-
- toString() - Method in class org.apache.cassandra.cql.Term
-
- toString() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- toString() - Method in class org.apache.cassandra.cql.WhereClause
-
- toString() - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- toString() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- toString() - Method in class org.apache.cassandra.cql3.CFName
-
- toString() - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- toString() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- toString() - Method in class org.apache.cassandra.cql3.ColumnSpecification
-
- toString() - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- toString() - Method in class org.apache.cassandra.cql3.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.functions.FunctionCall.Raw
-
- toString() - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- toString() - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- toString() - Method in class org.apache.cassandra.cql3.Relation
-
- toString() - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- toString() - Method in class org.apache.cassandra.cql3.ResultSet
-
- toString() - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- toString() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- toString() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- toString() - Method in class org.apache.cassandra.cql3.TypeCast
-
- toString() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- toString() - Method in class org.apache.cassandra.cql3.UserOptions
-
- toString() - Method in class org.apache.cassandra.db.ColumnFamily
-
- toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- toString() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- toString() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- toString() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- toString() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
-
- toString() - Method in class org.apache.cassandra.db.compaction.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(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Human-readable String from context.
- toString(ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
-
Human-readable String from context.
- toString() - Method in class org.apache.cassandra.db.CounterMutation
-
- toString(boolean) - Method in class org.apache.cassandra.db.CounterMutation
-
- toString() - Method in class org.apache.cassandra.db.DecoratedKey
-
- toString() - Method in class org.apache.cassandra.db.DeletionInfo
-
- toString() - Method in class org.apache.cassandra.db.DeletionTime
-
- toString() - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- toString() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- toString() - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- toString() - Method in class org.apache.cassandra.db.filter.QueryPath
-
- toString() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
-
- toString() - Method in class org.apache.cassandra.db.Keyspace
-
- 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() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- toString() - Method in class org.apache.cassandra.db.Memtable
-
- toString() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- toString() - Method in class org.apache.cassandra.db.RangeSliceReply
-
- toString() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- toString() - Method in class org.apache.cassandra.db.Row
-
- toString() - Method in class org.apache.cassandra.db.RowMutation
-
- toString(boolean) - Method in class org.apache.cassandra.db.RowMutation
-
- toString() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- toString() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- toString() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- toString() - Method in class org.apache.cassandra.db.Truncation
-
- toString() - Method in class org.apache.cassandra.dht.Bounds
-
- toString() - Method in class org.apache.cassandra.dht.BytesToken
-
- toString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.LocalToken
-
- toString() - Method in class org.apache.cassandra.dht.Range
-
- toString() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- toString(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- toString() - Method in class org.apache.cassandra.dht.Token
-
- toString() - Method in class org.apache.cassandra.gms.EndpointState
-
- toString() - Method in class org.apache.cassandra.gms.FailureDetector
-
- toString() - Method in class org.apache.cassandra.gms.GossipDigest
-
- toString() - Method in class org.apache.cassandra.gms.VersionedValue
-
- toString() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- toString() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- toString() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- toString() - Method in error org.apache.cassandra.io.FSReadError
-
- toString() - Method in error org.apache.cassandra.io.FSWriteError
-
- toString() - Method in class org.apache.cassandra.io.sstable.Component
-
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- toString() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- toString() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a string.
- toString(int) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
- toString(String) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a string converted
according to the encoding declared in enc
.
- toString() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- toString() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- toString() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- toString() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- toString() - Method in class org.apache.cassandra.net.MessageIn
-
- toString() - Method in class org.apache.cassandra.net.MessageOut
-
- toString() - Method in class org.apache.cassandra.repair.Differencer
-
- toString() - Method in class org.apache.cassandra.repair.RepairJobDesc
-
- toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- toString(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- toString(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- toString(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- toString(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- toString(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- toString(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- toString(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- toString(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- toString(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- toString(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- toString(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- toString(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- toString(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- toString(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- toString(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- toString() - Method in enum org.apache.cassandra.service.CacheService.CacheType
-
- toString() - Method in class org.apache.cassandra.service.paxos.Commit
-
- toString() - Method in class org.apache.cassandra.service.paxos.PrepareResponse
-
- toString() - Method in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.FileMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- toString() - Method in class org.apache.cassandra.streaming.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.RetryMessage
-
- toString() - Method in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- toString() - Method in class org.apache.cassandra.streaming.ProgressInfo
-
- toString() - Method in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
-
- toString() - Method in class org.apache.cassandra.streaming.StreamSummary
-
- toString() - Method in class org.apache.cassandra.tools.NodeToolHelp.NodeToolCommand
-
- toString() - Method in class org.apache.cassandra.transport.Event.SchemaChange
-
- toString() - Method in class org.apache.cassandra.transport.Event.StatusChange
-
- toString() - Method in class org.apache.cassandra.transport.Event.TopologyChange
-
- toString() - Method in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.BatchMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.EventMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.OptionsMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.QueryMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ReadyMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.RegisterMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- toString() - Method in class org.apache.cassandra.transport.messages.StartupMessage
-
- toString() - Method in class org.apache.cassandra.transport.messages.SupportedMessage
-
- toString() - Method in class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- toString() - Method in class org.apache.cassandra.utils.CounterId
-
- toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- 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.Pair
-
- toString() - Method in class org.apache.cassandra.utils.SemanticVersion
-
- total(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the aggregated count across all counter ids.
- total() - Method in class org.apache.cassandra.db.CounterColumn
-
- 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
-
- totalBytes - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- totalBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- totalCommitLogSize - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Current size used by all the commit log segments
- totalCompactionsCompleted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Total number of compactions since server [re]start
- totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Total disk space used by SSTables belonging to this CF, including obsolete ones waiting to be GC'd
- totalHints - Static variable in class org.apache.cassandra.metrics.StorageMetrics
-
- totalHintsInProgress - Static variable in class org.apache.cassandra.metrics.StorageMetrics
-
- totalIncomingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- totalLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Total latency in micro sec
- totalLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- totalOutgoingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- totalRows() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- totalSize() - Method in class org.apache.cassandra.streaming.StreamReader
-
- totalSize - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- totalSize() - Method in class org.apache.cassandra.streaming.StreamWriter
-
- totalTimeouts - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Total number of timeouts happened on this node
- toThrift() - Method in class org.apache.cassandra.config.CFMetaData
-
- toThrift(Map<ByteBuffer, ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- toThrift() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toThrift() - Method in class org.apache.cassandra.config.KSMetaData
-
- toThrift() - Method in class org.apache.cassandra.config.TriggerDefinition
-
- toThrift(Map<String, TriggerDefinition>) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- toThrift(RequestValidationException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- toThrift(InvalidRequestException) - 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
-
- toThriftPreparedResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toThriftResult() - Method in class org.apache.cassandra.cql3.ResultSet
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage
-
- toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
-
Transform this abstract bounds to a token abstract bounds.
- toTokenBounds() - Method in class org.apache.cassandra.dht.Bounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.Range
-
- toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
-
- tProtocolFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- TRACE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TRACE - Static variable in class org.apache.cassandra.cli.CliParser
-
- trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object[]) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(ByteBuffer, String, int) - Static method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object[]) - Static method in class org.apache.cassandra.tracing.Tracing
-
- TRACE_HEADER - Static variable in class org.apache.cassandra.tracing.Tracing
-
- TRACE_KS - Static variable in class org.apache.cassandra.tracing.Tracing
-
- trace_next_query() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- TraceEventsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- traceKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
-
- traceNextQuery() - Method in class org.apache.cassandra.cli.CliParser
-
- traceNextQuery() - Method in class org.apache.cassandra.service.QueryState
-
- traceSessionId() - Method in class org.apache.cassandra.cli.CliParser
-
- TraceSessionsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- TraceState - Class in org.apache.cassandra.tracing
-
ThreadLocal state for a tracing session.
- TraceState(InetAddress, UUID) - Constructor for class org.apache.cassandra.tracing.TraceState
-
- Tracing - Class in org.apache.cassandra.tracing
-
A trace session context.
- Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
-
- TracingAwareExecutorService - Interface in org.apache.cassandra.concurrent
-
- tracingId - Variable in class org.apache.cassandra.transport.Message.Response
-
- tracingProbability() - Method in class org.apache.cassandra.cli.CliParser
-
- tracingRequested - Variable in class org.apache.cassandra.transport.Message.Request
-
- tracker - Variable in class org.apache.cassandra.transport.SimpleClient
-
- tracksMaxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- tracksMaxMinColumnNames - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- transferFiles(InetAddress, Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send given SSTable files.
- transferRanges(InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Add transfer task to send data of specific keyspace and ranges.
- 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
.
- TransportException - Interface in org.apache.cassandra.exceptions
-
- transportFactory - Variable in class org.apache.cassandra.cli.CliSessionState
-
- tree - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
Merkle hash tree response.
- tree - Variable in class org.apache.cassandra.repair.TreeResponse
-
- tree - Variable in class org.apache.cassandra.repair.Validator
-
- TreeMapBackedSortedColumns - Class in org.apache.cassandra.db
-
- TreeResponse - Class in org.apache.cassandra.repair
-
Merkle tree response sent from given endpoint.
- TreeResponse(InetAddress, MerkleTree) - Constructor for class org.apache.cassandra.repair.TreeResponse
-
- trickle_fsync - Variable in class org.apache.cassandra.config.Config
-
- trickle_fsync_interval_in_kb - Variable in class org.apache.cassandra.config.Config
-
- TriggerDefinition - Class in org.apache.cassandra.config
-
- TriggerExecutor - Class in org.apache.cassandra.triggers
-
- triggers(Map<String, TriggerDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
-
- trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
-
- trim(ColumnFamily, int, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- trimTrailingZeros() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Lowers numWords, the number of words in use,
by checking for trailing zero words.
- trivialReduceIsTrivial() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- TRUNCATE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
-
- truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- truncate(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- truncate(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- truncate(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Truncates (deletes) the given columnFamily from the provided keyspace.
- truncate(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- truncate_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- truncateBlocking() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Truncate deletes the entire column family's data with no expensive tombstone creation
- truncateBlocking(long) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- truncateBlocking(long) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Truncate all the data from the current index
- truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the truncate operatoin, which effectively deletes all data from
the column family cfname
- 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
-
- 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
-
- TruncateResponse.TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- TruncateResponseHandler - Class in org.apache.cassandra.service
-
- TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
-
- truncateStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- truncateStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- truncateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- TruncateStatement - Class in org.apache.cassandra.cql3.statements
-
- TruncateStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.TruncateStatement
-
- 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
-
- truststore - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- tryCloseFD(int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- tryComponentFromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
- tryFcntl(int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- tryGetLeveledManifest() - Method in class org.apache.cassandra.db.Directories
-
Deprecated.
- tryMlockall() - Static method in class org.apache.cassandra.utils.CLibrary
-
- tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.CLibrary
-
- trySkipCache(int, long, int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- trySync(int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- TServerCustomFactory - Class in org.apache.cassandra.thrift
-
Helper implementation to create a thrift TServer based on one of the common types we support (sync, async, 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
-
- TServerFactory.Args() - Constructor for class org.apache.cassandra.thrift.TServerFactory.Args
-
- TTL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TTL - Static variable in class org.apache.cassandra.cli.CliParser
-
- TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
-
- type - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- type - Variable in class org.apache.cassandra.config.ColumnDefinition
-
- type - Variable in class org.apache.cassandra.cql.CQLStatement
-
- type - Variable in class org.apache.cassandra.cql.Operation
-
- type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
-
- type - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- 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 - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- TYPE_NAME - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
- TYPE_NAME - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- TypeCast - Class in org.apache.cassandra.cql3
-
- TypeCast(CQL3Type, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TypeCast
-
- typeIdentifier() - Method in class org.apache.cassandra.cli.CliParser
-
- 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
-
- TypeSerializer<T> - Interface in org.apache.cassandra.serializers
-
- TypeSizes - Class in org.apache.cassandra.db
-
- TypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes
-
- TypeSizes.NativeDBTypeSizes - Class in org.apache.cassandra.db
-
- TypeSizes.NativeDBTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- TypeSizes.VIntEncodedTypeSizes - Class in org.apache.cassandra.db
-
- TypeSizes.VIntEncodedTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- V - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- V - Static variable in class org.apache.cassandra.cql.CqlParser
-
- V - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- V - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- validate() - Method in class org.apache.cassandra.config.CFMetaData
-
- validate() - Method in class org.apache.cassandra.config.KSMetaData
-
- validate() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- validate() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating, and must be called prior to access.
- validate() - Method in class org.apache.cassandra.cql3.CFPropDefs
-
- validate(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform additional validation required by the statment.
- validate() - Method in class org.apache.cassandra.cql3.KSPropDefs
-
- validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- validate() - Method in class org.apache.cassandra.cql3.UserOptions
-
- validate(Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- 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.CollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- validate() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.AsciiSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UTF8Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative validation function used by CollectionsType in conjunction with CompositeType.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validateColumn(CFMetaData, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateColumnData(CFMetaData, Column, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
Validates the data part of the column (everything in the Column object but the name, which is assumed to be valid)
- validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnName(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateColumnNames(Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- 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
- validateColumns(Iterable<Column>) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateCompactionOptions(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Like getComparator, but validates that @param i does not exceed the defined range
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- validateCompatility(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Validates configuration of IAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Validates configuration of IAuthorizer implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Validates configuration of IInternodeAuthenticator implementation (if configurable).
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.Column
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.CounterColumn
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.DeletedColumn
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.RangeTombstone
-
- validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForCasCommit(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForRead(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForWrite(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyAlias(CFMetaData, String) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspace(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotSystem(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotYetExisting(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateLogin() - Method in class org.apache.cassandra.service.ClientState
-
- validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
-
- validateMinusSupplied(Object, Term, IntStream) - Method in class org.apache.cassandra.cql.CqlParser
-
- validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateName(CFMetaData) - Method in class org.apache.cassandra.db.Column
-
- validateNewMessage(Message.Type, int, int) - Method in class org.apache.cassandra.transport.ServerConnection
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- validateOptions() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Validates the index_options passed in the ColumnDef
- validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- ValidationComplete - Class in org.apache.cassandra.repair.messages
-
ValidationComplete message is sent when validation compaction completed successfully.
- ValidationComplete(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- ValidationComplete(RepairJobDesc, MerkleTree) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- validationComplete(RepairJobDesc, InetAddress, MerkleTree) - Method in class org.apache.cassandra.repair.RepairSession
-
Receive merkle tree response or failed response from endpoint
for current repair job.
- 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
-
- ValidationRequest.ValidationRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- validator - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- validator - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- Validator - Class in org.apache.cassandra.repair
-
Handles the building of a merkle tree for a column family.
- Validator(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.Validator
-
Create Validator with default size of initial Merkle Tree.
- Validator(RepairJobDesc, InetAddress, MerkleTree, int) - Constructor for class org.apache.cassandra.repair.Validator
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- value() - Method in class org.apache.cassandra.cli.CliParser
-
- value - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- value - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- value() - Method in class org.apache.cassandra.cql3.CqlParser
-
- value - Variable in class org.apache.cassandra.db.Column
-
- value() - Method in class org.apache.cassandra.db.Column
-
- value - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
-
- value - Variable in class org.apache.cassandra.gms.VersionedValue
-
- value() - Method in class org.apache.cassandra.utils.DefaultDouble
-
- value() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- value - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.ListType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.MapType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.SetType
-
- valueFactory - Variable in class org.apache.cassandra.service.StorageService
-
- valueOf(String) - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
-
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.Relation.Type
-
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.db.ColumnFamilyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnSerializer.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.RowPosition.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.WriteType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.gms.ApplicationState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.hadoop.pig.AbstractCassandraStorage.MarshallerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.RequestType
-
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.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.messages.ResultMessage.SchemaChange.Change
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.auth.Permission
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ColumnDefinition.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.config.Config.CommitLogSync
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.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.Relation.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.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(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- values(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- values(List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- values() - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ColumnSerializer.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
-
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 - Variable in class org.apache.cassandra.db.marshal.MapType
-
- values() - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.RowPosition.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.WriteType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.gms.ApplicationState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.hadoop.pig.AbstractCassandraStorage.MarshallerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.serializers.MapSerializer
-
- values() - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.RequestType
-
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.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.messages.ResultMessage.SchemaChange.Change
-
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
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Sets
-
- VarcharAsBlobFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- variables - Variable in class org.apache.cassandra.cql3.UpdateParameters
-
- VariableSpecifications - Class in org.apache.cassandra.cql3
-
- VariableSpecifications(List<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.VariableSpecifications
-
- verb - Variable in class org.apache.cassandra.net.MessageIn
-
- verb - Variable in class org.apache.cassandra.net.MessageOut
-
- verbose - Variable in class org.apache.cassandra.cli.CliSessionState
-
- verbSerializers - Static variable in class org.apache.cassandra.net.MessagingService
-
Messages we receive in IncomingTcpConnection have a Verb that tells us what kind of message it is.
- verbStages - Static variable in class org.apache.cassandra.net.MessagingService
-
- verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- version - Variable in class org.apache.cassandra.gms.VersionedValue
-
- version - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
version has the following format: [a-z]+
- version - Variable in class org.apache.cassandra.net.MessageIn
-
- version - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable version
- version - Variable in class org.apache.cassandra.transport.Frame.Header
-
- VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
-
- 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
-
- VersionedValue.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
-
- VINT - Static variable in class org.apache.cassandra.db.TypeSizes
-