- CachedHashDecoratedKey - Class in org.apache.cassandra.db
-
- CachedHashDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.CachedHashDecoratedKey
-
- cachedOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return a cached TokenMetadata with only tokenToEndpointMap, i.e., the same as cloneOnlyTokenMap but
uses a cached copy that is invalided when the ring changes, so in the common case
no extra locking is required.
- cacheFullPartitions() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
-
- CacheKey - Class in org.apache.cassandra.cache
-
- CacheKey(Pair<String, String>) - Constructor for class org.apache.cassandra.cache.CacheKey
-
- cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- CacheKey() - Constructor for class org.apache.cassandra.service.FileCacheService.CacheKey
-
- CacheMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ICache
.
- CacheMetrics(String, ICache) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
-
Create metrics for given cache.
- CacheProvider<K,V> - Interface in org.apache.cassandra.cache
-
- CacheService - Class in org.apache.cassandra.service
-
- CacheService.CacheType - Enum in org.apache.cassandra.service
-
- CacheService.CounterCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
-
- CacheServiceMBean - Interface in org.apache.cassandra.service
-
- cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- caching(CachingOptions) - Method in class org.apache.cassandra.config.CFMetaData
-
- caching - Variable in class org.apache.cassandra.thrift.CfDef
-
- CachingOptions - Class in org.apache.cassandra.cache
-
- CachingOptions(CachingOptions.KeyCache, CachingOptions.RowCache) - Constructor for class org.apache.cassandra.cache.CachingOptions
-
- CachingOptions.KeyCache - Class in org.apache.cassandra.cache
-
- CachingOptions.KeyCache.Type - Enum in org.apache.cassandra.cache
-
- CachingOptions.RowCache - Class in org.apache.cassandra.cache
-
- CachingOptions.RowCache.Type - Enum in org.apache.cassandra.cache
-
- calculateHintTTL(Mutation) - Static method in class org.apache.cassandra.db.HintedHandOffManager
-
- calculateIsDense(AbstractType<?>, Collection<ColumnDefinition>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- 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) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Calculate pending ranges according to bootsrapping and leaving nodes.
- calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
-
- calculateSamplingLevel(int, int, long, int, int) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- calculateSchemaDigest() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
Read schema from system keyspace and calculate MD5 digest of every row, resulting digest
will be converted into UUID which would act as content-based version of the schema.
- calculateStreamAndFetchRanges(Collection<Range<Token>>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.StorageService
-
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
- callback - Variable in class org.apache.cassandra.net.CallbackInfo
-
- callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- callbackDeserializers - Static variable in class org.apache.cassandra.net.MessagingService
-
A Map of what kind of serializer to wire up to a REQUEST_RESPONSE callback, based on outbound Verb.
- CallbackInfo - Class in org.apache.cassandra.net
-
Encapsulates the callback information.
- CallbackInfo(InetAddress, IAsyncCallback, IVersionedSerializer<?>, boolean) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
Create CallbackInfo without sent message
- calledOnNullInput - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- canBeNonFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- cancel(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the reader from the set we're modifying
- cancel(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the readers from the set we're modifying
- cancel() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Should only be called by the owning thread.
- cancel() - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
-
- Candidate(Iterator<In>, Comparator<In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
-
- canHandleIndexClause(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- canLogin(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- canLogin(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Return true if there exists a Role with the given name which has login
privileges.
- CANONICAL_SSTABLES - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- capacity() - Method in interface org.apache.cassandra.cache.ICache
-
- capacity() - Method in class org.apache.cassandra.cache.SerializingCache
-
- capacity() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Cache capacity in bytes
- capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity in bits (1 greater than the index of the last bit)
- captureWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- cardinality - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
Default cardinality estimation method is to use HyperLogLog++.
- cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- cardinality - Variable in class org.apache.cassandra.utils.TopKSampler.SamplerResult
-
- cardinalityEstimator - Variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- cas(String, String, ByteBuffer, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState) - Static method in class org.apache.cassandra.service.StorageProxy
-
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- cas() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Atomic compare and set.
- cas() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.cas
-
- cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- cas_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
- cas_args(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
- cas_args(Cassandra.cas_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
Performs a deep copy on other.
- cas_call(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.cas_call
-
- cas_contention_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- cas_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
- cas_result(CASResult, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
- cas_result(Cassandra.cas_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
Performs a deep copy on other.
- CASClientRequestMetrics - Class in org.apache.cassandra.metrics
-
- CASClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- casCommit - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
CAS Commit metrics
- casCommit - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Commit metrics
- casPrepare - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
CAS Prepare metrics
- casPrepare - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Prepare metric
- casPropose - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
CAS Propose metrics
- casPropose - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
CAS Propose metrics
- CASRequest - Interface in org.apache.cassandra.service
-
Abstract the conditions and updates for a CAS operation.
- CASResult - Class in org.apache.cassandra.thrift
-
- CASResult() - Constructor for class org.apache.cassandra.thrift.CASResult
-
- CASResult(boolean) - Constructor for class org.apache.cassandra.thrift.CASResult
-
- CASResult(CASResult) - Constructor for class org.apache.cassandra.thrift.CASResult
-
Performs a deep copy on other.
- CASResult._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra - Class in org.apache.cassandra.thrift
-
- Cassandra() - Constructor for class org.apache.cassandra.thrift.Cassandra
-
- Cassandra.add_args - Class in org.apache.cassandra.thrift
-
- Cassandra.add_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.add_result - Class in org.apache.cassandra.thrift
-
- Cassandra.add_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.AsyncClient - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.add_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.atomic_batch_mutate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.batch_mutate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.cas_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_cluster_name_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_keyspaces_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_local_ring_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_partitioner_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_ring_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_schema_versions_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_snitch_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_splits_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_splits_ex_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_token_map_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_version_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_prepared_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_prepared_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.Factory - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_count_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_indexed_slices_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_multi_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_paged_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_range_slices_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.insert_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.login_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.multiget_count_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.multiget_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.prepare_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.prepare_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.remove_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.remove_counter_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.set_cql_version_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.set_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_add_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_add_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_drop_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_drop_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_update_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_update_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.trace_next_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.truncate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncIface - Interface in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.add<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.atomic_batch_mutate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.batch_mutate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.cas<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_cluster_name<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_keyspaces<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_local_ring<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_partitioner<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_ring<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_schema_versions<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_snitch<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_splits<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_splits_ex<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_token_map<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_version<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_prepared_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_prepared_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_count<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_indexed_slices<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_multi_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_paged_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_range_slices<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.insert<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.login<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.multiget_count<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.multiget_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.prepare_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.prepare_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.remove<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.remove_counter<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.set_cql_version<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.set_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_add_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_add_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_drop_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_drop_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_update_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_update_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.trace_next_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.truncate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.atomic_batch_mutate_args - Class in org.apache.cassandra.thrift
-
- Cassandra.atomic_batch_mutate_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.atomic_batch_mutate_result - Class in org.apache.cassandra.thrift
-
- Cassandra.atomic_batch_mutate_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.batch_mutate_args - Class in org.apache.cassandra.thrift
-
- Cassandra.batch_mutate_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.batch_mutate_result - Class in org.apache.cassandra.thrift
-
- Cassandra.batch_mutate_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.cas_args - Class in org.apache.cassandra.thrift
-
- Cassandra.cas_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.cas_result - Class in org.apache.cassandra.thrift
-
- Cassandra.cas_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.Client - Class in org.apache.cassandra.thrift
-
- Cassandra.Client.Factory - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_cluster_name_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_cluster_name_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_cluster_name_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_cluster_name_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_keyspace_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_keyspace_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_keyspaces_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_keyspaces_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_keyspaces_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_keyspaces_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_local_ring_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_local_ring_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_local_ring_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_local_ring_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_partitioner_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_partitioner_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_partitioner_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_partitioner_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_ring_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_ring_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_ring_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_ring_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_schema_versions_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_schema_versions_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_schema_versions_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_schema_versions_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_snitch_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_snitch_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_snitch_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_snitch_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_splits_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_splits_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_splits_ex_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_splits_ex_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_splits_ex_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_splits_ex_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_splits_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_splits_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_token_map_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_token_map_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_token_map_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_token_map_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_version_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_version_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.describe_version_result - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_version_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_cql3_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_cql3_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_cql3_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_cql3_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_cql_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_cql_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_cql_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_cql_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_prepared_cql3_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_prepared_cql3_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_prepared_cql3_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_prepared_cql3_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_prepared_cql_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_prepared_cql_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.execute_prepared_cql_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.execute_prepared_cql_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_count_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_count_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_count_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_count_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_indexed_slices_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_indexed_slices_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_indexed_slices_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_indexed_slices_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_multi_slice_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_multi_slice_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_multi_slice_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_multi_slice_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_paged_slice_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_paged_slice_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_paged_slice_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_paged_slice_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_range_slices_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_range_slices_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_range_slices_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_range_slices_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_slice_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_slice_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.get_slice_result - Class in org.apache.cassandra.thrift
-
- Cassandra.get_slice_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.Iface - Interface in org.apache.cassandra.thrift
-
- Cassandra.insert_args - Class in org.apache.cassandra.thrift
-
- Cassandra.insert_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.insert_result - Class in org.apache.cassandra.thrift
-
- Cassandra.insert_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.login_args - Class in org.apache.cassandra.thrift
-
- Cassandra.login_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.login_result - Class in org.apache.cassandra.thrift
-
- Cassandra.login_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.multiget_count_args - Class in org.apache.cassandra.thrift
-
- Cassandra.multiget_count_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.multiget_count_result - Class in org.apache.cassandra.thrift
-
- Cassandra.multiget_count_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.multiget_slice_args - Class in org.apache.cassandra.thrift
-
- Cassandra.multiget_slice_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.multiget_slice_result - Class in org.apache.cassandra.thrift
-
- Cassandra.multiget_slice_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.prepare_cql3_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.prepare_cql3_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.prepare_cql3_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.prepare_cql3_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.prepare_cql_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.prepare_cql_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.prepare_cql_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.prepare_cql_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.Processor<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.add<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.atomic_batch_mutate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.batch_mutate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.cas<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_cluster_name<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_keyspaces<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_local_ring<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_partitioner<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_ring<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_schema_versions<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_snitch<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_splits<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_splits_ex<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_token_map<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_version<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_prepared_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_prepared_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_count<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_indexed_slices<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_multi_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_paged_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_range_slices<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.insert<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.login<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.multiget_count<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.multiget_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.prepare_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.prepare_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.remove<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.remove_counter<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.set_cql_version<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.set_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_add_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_add_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_drop_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_drop_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_update_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_update_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.trace_next_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.truncate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_args - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.remove_counter_args - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_counter_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.remove_counter_result - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_counter_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.remove_result - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.set_cql_version_args - Class in org.apache.cassandra.thrift
-
- Cassandra.set_cql_version_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.set_cql_version_result - Class in org.apache.cassandra.thrift
-
- Cassandra.set_cql_version_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.set_keyspace_args - Class in org.apache.cassandra.thrift
-
- Cassandra.set_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.set_keyspace_result - Class in org.apache.cassandra.thrift
-
- Cassandra.set_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_add_column_family_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_add_column_family_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_add_column_family_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_add_column_family_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_add_keyspace_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_add_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_add_keyspace_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_add_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_drop_column_family_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_drop_column_family_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_drop_column_family_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_drop_column_family_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_drop_keyspace_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_drop_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_drop_keyspace_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_drop_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_update_column_family_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_update_column_family_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_update_column_family_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_update_column_family_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_update_keyspace_args - Class in org.apache.cassandra.thrift
-
- Cassandra.system_update_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.system_update_keyspace_result - Class in org.apache.cassandra.thrift
-
- Cassandra.system_update_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.trace_next_query_args - Class in org.apache.cassandra.thrift
-
- Cassandra.trace_next_query_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.trace_next_query_result - Class in org.apache.cassandra.thrift
-
- Cassandra.trace_next_query_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.truncate_args - Class in org.apache.cassandra.thrift
-
- Cassandra.truncate_args._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Cassandra.truncate_result - Class in org.apache.cassandra.thrift
-
- Cassandra.truncate_result._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- 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
-
Deprecated.
- CassandraAuthorizer - Class in org.apache.cassandra.auth
-
CassandraAuthorizer is an IAuthorizer implementation that keeps
user permissions internally in C* using the system_auth.role_permissions
table.
- CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
-
- cassandraConstants - Class in org.apache.cassandra.thrift
-
- cassandraConstants() - Constructor for class org.apache.cassandra.thrift.cassandraConstants
-
- CassandraDaemon - Class in org.apache.cassandra.service
-
- CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon(boolean) - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon.Server - Interface in org.apache.cassandra.service
-
- CassandraException - Exception in org.apache.cassandra.exceptions
-
- CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraMetricsRegistry - Class in org.apache.cassandra.metrics
-
Makes integrating 3.0 metrics API with 2.0.
- CassandraMetricsRegistry.JmxCounterMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.JmxGaugeMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.JmxHistogramMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.JmxMeterMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.JmxTimerMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.MetricMBean - Interface in org.apache.cassandra.metrics
-
- CassandraMetricsRegistry.MetricName - Class in org.apache.cassandra.metrics
-
A value class encapsulating a metric's owning class and name.
- CassandraRoleManager - Class in org.apache.cassandra.auth
-
Responsible for the creation, maintenance and deletion of roles
for the purposes of authentication and authorization.
- CassandraRoleManager() - Constructor for class org.apache.cassandra.auth.CassandraRoleManager
-
- CassandraServer - Class in org.apache.cassandra.thrift
-
- CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
-
- CassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
Deprecated.
- CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- CassandraStorage.MarshallerType - Enum in org.apache.cassandra.hadoop.pig
-
Deprecated.
- cassandraToObj(AbstractType, ByteBuffer, int) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
-
Deprecated.
- cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- CassandraVersion - Class in org.apache.cassandra.utils
-
Implements versioning used in Cassandra and CQL.
- CassandraVersion(String) - Constructor for class org.apache.cassandra.utils.CassandraVersion
-
Parse a version from a string.
- CBCodec<T> - Interface in org.apache.cassandra.transport
-
- CBuilder - Interface in org.apache.cassandra.db.composites
-
A builder of Composite.
- CBUtil - Class in org.apache.cassandra.transport
-
ByteBuf utility methods.
- ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- Cell - Interface in org.apache.cassandra.db
-
Cell is immutable, which prevents all kinds of confusion in a multithreaded environment.
- cellDataSize() - Method in class org.apache.cassandra.db.AbstractCell
-
- cellDataSize() - Method in class org.apache.cassandra.db.BufferCounterCell
-
- cellDataSize() - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- cellDataSize() - Method in interface org.apache.cassandra.db.Cell
-
- cellDataSize() - Method in class org.apache.cassandra.db.NativeCounterCell
-
- cellDataSize() - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- cellFromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- cellFromByteBuffer(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Deserialize a Composite from a ByteBuffer.
- cellName - Variable in class org.apache.cassandra.cache.CounterCacheKey
-
- CellName - Interface in org.apache.cassandra.db.composites
-
A CellName is a Composite, but for which, for the sake of CQL3, we
distinguish different parts: a CellName has first a number of clustering
components, followed by the CQL3 column name, and then possibly followed by
a collection element part.
- cellName - Variable in class org.apache.cassandra.service.pager.PagingState
-
- CellNames - Class in org.apache.cassandra.db.composites
-
- CellNameType - Interface in org.apache.cassandra.db.composites
-
The type of CellNames.
- CellNameType.Deserializer - Interface in org.apache.cassandra.db.composites
-
- cells_per_row_to_cache - Variable in class org.apache.cassandra.thrift.CfDef
-
- cellSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- cellSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- cf - Variable in class org.apache.cassandra.db.CFRowAdder
-
- cf - Variable in class org.apache.cassandra.db.Row
-
- cf - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics.ColumnFamilyHistogram
-
- cf_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- cf_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- cf_defs - Variable in class org.apache.cassandra.thrift.KsDef
-
- CfDef - Class in org.apache.cassandra.thrift
-
- CfDef() - Constructor for class org.apache.cassandra.thrift.CfDef
-
- CfDef(String, String) - Constructor for class org.apache.cassandra.thrift.CfDef
-
- CfDef(CfDef) - Constructor for class org.apache.cassandra.thrift.CfDef
-
Performs a deep copy on other.
- CfDef._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
convert string back to CfDef
- cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
convert string back to CfDef
- cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
convert CfDef to string
- cfdefToString(TableMetadata) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
convert CfDef to string
- CfHistograms - Class in org.apache.cassandra.tools.nodetool
-
- CfHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.CfHistograms
-
Deprecated.
- cfId - Variable in class org.apache.cassandra.config.CFMetaData
-
- cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- cfId - Variable in class org.apache.cassandra.streaming.StreamReader
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamTask
-
- cfIds - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- cfIdSerializedSize(UUID, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- cfm - Variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
The Column Family meta data
- cfm - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- cfm - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- CFMetaData - Class in org.apache.cassandra.config
-
This class can be tricky to modify.
- CFMetaData(String, String, ColumnFamilyType, CellNameType) - Constructor for class org.apache.cassandra.config.CFMetaData
-
Create new ColumnFamily metadata with generated random ID.
- CFMetaData(String, String, ColumnFamilyType, CellNameType, UUID) - Constructor for class org.apache.cassandra.config.CFMetaData
-
- cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
-
- CFMetaData.SpeculativeRetry - Class in org.apache.cassandra.config
-
- CFMetaData.SpeculativeRetry.RetryType - Enum in org.apache.cassandra.config
-
- cfName - Variable in class org.apache.cassandra.config.CFMetaData
-
- CFName - Class in org.apache.cassandra.cql3
-
- CFName() - Constructor for class org.apache.cassandra.cql3.CFName
-
- cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- cfName - 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
-
- cfName - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- cfName - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- cfname - Variable in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- CFPropDefs - Class in org.apache.cassandra.cql3.statements
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.CFPropDefs
-
- CFRowAdder - Class in org.apache.cassandra.db
-
Convenience object to populate a given CQL3 row in a ColumnFamily object.
- CFRowAdder(ColumnFamily, Composite, long) - Constructor for class org.apache.cassandra.db.CFRowAdder
-
- CFRowAdder(ColumnFamily, Composite, long, int) - Constructor for class org.apache.cassandra.db.CFRowAdder
-
- cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- cfs - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- cfs - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- cfs - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
-
- cfs - Variable in class org.apache.cassandra.db.Memtable
-
- CfSplit - Class in org.apache.cassandra.thrift
-
Represents input splits used by hadoop ColumnFamilyRecordReaders
- CfSplit() - Constructor for class org.apache.cassandra.thrift.CfSplit
-
- CfSplit(String, String, long) - Constructor for class org.apache.cassandra.thrift.CfSplit
-
- CfSplit(CfSplit) - Constructor for class org.apache.cassandra.thrift.CfSplit
-
Performs a deep copy on other.
- CfSplit._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CFStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that apply on a given column family.
- CFStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.CFStatement
-
- CfStats - Class in org.apache.cassandra.tools.nodetool
-
- CfStats() - Constructor for class org.apache.cassandra.tools.nodetool.CfStats
-
Deprecated.
- cfstore - Variable in class org.apache.cassandra.db.lifecycle.Tracker
-
- cfType - Variable in class org.apache.cassandra.config.CFMetaData
-
- chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
-
Construct a chain of resource parents starting with the resource and ending with the root.
- change - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- change - Variable in class org.apache.cassandra.transport.Event.TopologyChange
-
- change - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- changeEvent() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- channel() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- channel() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- channel - Variable in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- channel() - Method in interface org.apache.cassandra.io.util.ICompressedFile
-
- channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- channel - Variable in class org.apache.cassandra.io.util.SegmentedFile
-
- channel - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- channel() - Method in class org.apache.cassandra.transport.Connection
-
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
-
- ChannelProxy - Class in org.apache.cassandra.io.util
-
A proxy of a FileChannel that:
- implements reference counting
- exports only thread safe FileChannel operations
- wraps IO exceptions into runtime exceptions
Tested by RandomAccessReaderTest.
- ChannelProxy(String) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(File) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(String, FileChannel) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- ChannelProxy(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
-
- channelRead0(ChannelHandlerContext, Message.Request) - Method in class org.apache.cassandra.transport.Message.Dispatcher
-
- CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform any access verification necessary for the statement.
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- checkAndClear() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
atomically: cancels the Signal if !isSet(), or returns true if isSignalled()
- checkAvailableDiskSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- checkBindValueSet(ByteBuffer, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified bind marker value is set to a meaningful value.
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- checkContainsNoDuplicates(List<?>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified list does not contains duplicates.
- checkContainsOnly(List<E>, List<E>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified list contains only the specified elements.
- checkDatacenter - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkDataDirs - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkFalse(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is false
.
- checkFalse(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is false
.
- checkForDuplicateNames(UserType) - Static method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- checkForEndpointCollision() - Method in class org.apache.cassandra.service.StorageService
-
- checkForExpiredSSTableBlockers(Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
-
- checkHealth() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
One of three things will happen if you try to read the system keyspace:
1.
- checkJemalloc - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkJMXPorts - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkJnaInitialization - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkNotNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is NOT null
.
- checkNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is null
.
- checkNull(T, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is null
.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- checkPermission(ClientState, Permission, RoleResource) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- checkpoint() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
call when a consistent batch of changes is ready to be made atomically visible
these will be exposed in the Tracker atomically, or an exception will be thrown; in this case
the transaction should be rolled back
- checkRack - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkRemaining(ByteBuffer, int, int) - Static method in class org.apache.cassandra.db.composites.AbstractCType
-
- checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- checkSSTablesFormat - Static variable in class org.apache.cassandra.service.StartupChecks
-
- ChecksummedRandomAccessReader - Class in org.apache.cassandra.io.util
-
- ChecksummedRandomAccessReader(File, ChannelProxy, DataIntegrityMetadata.ChecksumValidator) - Constructor for class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
-
- ChecksummedRandomAccessReader.CorruptFileException - Exception in org.apache.cassandra.io.util
-
- ChecksummedSequentialWriter - Class in org.apache.cassandra.io.util
-
- ChecksummedSequentialWriter(File, int, File) - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- ChecksummedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.util
-
- checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- ChecksumValidator(Checksum, RandomAccessReader, String) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- ChecksumWriter(DataOutput) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- checkSystemKeyspaceState - Static variable in class org.apache.cassandra.service.StartupChecks
-
- checkTrue(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is true
.
- checkTrue(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is true
.
- checkValidLaunchDate - Static variable in class org.apache.cassandra.service.StartupChecks
-
- chooseGroup(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If the group is empty, use the package name of the given class.
- chooseName(String, Method) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If name is empty, use the name of the given method.
- chooseType(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
If the type is empty, use the simple name of the given class.
- Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- CHUNK_LENGTH_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
-
- chunkSegments() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- chunkSegments() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- chunkSegments() - Method in interface org.apache.cassandra.io.util.ICompressedFile
-
- chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- CIPHER_SUITES - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- CLASS - Static variable in class org.apache.cassandra.config.TriggerDefinition
-
- class_name - Variable in class org.apache.cassandra.config.ParameterizedClass
-
- classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- classOption - Variable in class org.apache.cassandra.config.TriggerDefinition
-
- clean(ByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cleanThreshold - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- Cleanup(ChannelProxy, CompressionMetadata, TreeMap<Long, MappedByteBuffer>) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Cleanup
-
- Cleanup(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile.Cleanup
-
- Cleanup(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Cleanup
-
- cleanup() - Method in class org.apache.cassandra.streaming.StreamLockfile
-
- Cleanup - Class in org.apache.cassandra.tools.nodetool
-
- Cleanup() - Constructor for class org.apache.cassandra.tools.nodetool.Cleanup
-
- cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
Deprecated.
- cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- CleanupMessage - Class in org.apache.cassandra.repair.messages
-
Message to cleanup repair resources on replica nodes.
- CleanupMessage(UUID) - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage
-
- CleanupMessage.CleanupMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- CleanupMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- cleanupOnSuccess(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- cleanupOnSuccess(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- clear() - Method in interface org.apache.cassandra.cache.ICache
-
- clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- clear() - Method in class org.apache.cassandra.cache.SerializingCache
-
- clear() - Method in class org.apache.cassandra.config.Schema
-
Clear all KS/CF metadata and reset version.
- clear() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- clear() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clear this column family, removing all columns and deletion info.
- clear(String) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear(String, Schema) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear() - Method in class org.apache.cassandra.metrics.ClearableHistogram
-
- clear() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
- clear() - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- clear() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- clear() - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- clear() - Method in class org.apache.cassandra.thrift.CASResult
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- clear() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- clear() - Method in class org.apache.cassandra.thrift.CfDef
-
- clear() - Method in class org.apache.cassandra.thrift.CfSplit
-
- clear() - Method in class org.apache.cassandra.thrift.Column
-
- clear() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- clear() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- clear() - Method in class org.apache.cassandra.thrift.ColumnParent
-
- clear() - Method in class org.apache.cassandra.thrift.ColumnPath
-
- clear() - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- clear() - Method in class org.apache.cassandra.thrift.CounterColumn
-
- clear() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- clear() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- clear() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- clear() - Method in class org.apache.cassandra.thrift.CqlResult
-
- clear() - Method in class org.apache.cassandra.thrift.CqlRow
-
- clear() - Method in class org.apache.cassandra.thrift.Deletion
-
- clear() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- clear() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- clear() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- clear() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- clear() - Method in class org.apache.cassandra.thrift.KeyCount
-
- clear() - Method in class org.apache.cassandra.thrift.KeyRange
-
- clear() - Method in class org.apache.cassandra.thrift.KeySlice
-
- clear() - Method in class org.apache.cassandra.thrift.KsDef
-
- clear() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- clear() - Method in class org.apache.cassandra.thrift.Mutation
-
- clear() - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- clear() - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- clear() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- clear() - Method in class org.apache.cassandra.thrift.SliceRange
-
- clear() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- clear() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- clear() - Method in class org.apache.cassandra.thrift.TokenRange
-
- clear() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- clear() - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- clear() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- clear() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- clear() - Method in class org.apache.cassandra.utils.BloomFilter
-
- clear() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- clear() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- clear() - Method in interface org.apache.cassandra.utils.IFilter
-
- clear(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
clears the bit.
- clear() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- clear(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- clear() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- clear(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
clears a bit.
- clear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
clears a bit.
- clear(int, int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Clears a range of bits.
- clear(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Clears a range of bits.
- clear() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- clear_snapshot - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- ClearableHistogram - Class in org.apache.cassandra.metrics
-
Adds ability to reset a histogram
- ClearableHistogram(DecayingEstimatedHistogramReservoir) - Constructor for class org.apache.cassandra.metrics.ClearableHistogram
-
Creates a new Histogram
with the given reservoir.
- clearAllLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Remove all the local of a context (but keep global).
- clearCallbacksUnsafe() - Method in class org.apache.cassandra.net.MessagingService
-
- clearEphemeralSnapshots(Directories) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- clearInternalStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Clear our internal statmeent cache for test purposes.
- clearKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace definition from system
- clearMessageSinks() - Method in class org.apache.cassandra.net.MessagingService
-
- clearSizeEstimates(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Clears size estimates for a table (on table drop)
- clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Clear all the snapshots for a given column family.
- clearSnapshot(String, List<File>) - Static method in class org.apache.cassandra.db.Directories
-
- clearSnapshot(String, String) - Static method in class org.apache.cassandra.db.Keyspace
-
Clear all the snapshots for a given keyspace.
- clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Remove the snapshot with the given name from the given keyspaces.
- clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Remove the snapshot with the given name from the given keyspaces.
- clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Remove all the existing snapshots.
- ClearSnapshot - Class in org.apache.cassandra.tools.nodetool
-
- ClearSnapshot() - Constructor for class org.apache.cassandra.tools.nodetool.ClearSnapshot
-
- clearSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Clears persisted read rates from system.sstable_activity for SSTables that have been deleted.
- clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
For testing.
- clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
-
used by tests
- CLibrary - Class in org.apache.cassandra.utils
-
- Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- Client(TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
-
- Client(TProtocol, TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
-
- Client - Class in org.apache.cassandra.transport
-
- Client(String, int, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
-
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- ClientEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
-
- ClientMetrics - Class in org.apache.cassandra.metrics
-
- ClientRequestMetrics - Class in org.apache.cassandra.metrics
-
- ClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
-
- ClientState - Class in org.apache.cassandra.service
-
State related to a client connection.
- ClientState(InetSocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
-
- ClientWarn - Class in org.apache.cassandra.service
-
- ClientWarn.State - Class in org.apache.cassandra.service
-
- clientWarnState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
-
- clock - Variable in class org.apache.cassandra.db.ClockAndCount
-
- ClockAndCount - Class in org.apache.cassandra.db
-
- clone(AbstractAllocator) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- clone() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
-
Allocate a slice of the given length.
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
-
- clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
-
- clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave operations have finished.
- cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave, and move operations have finished.
- cloneMe() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clones the column map.
- cloneMeShallow(ColumnFamily.Factory<T>, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneMeShallow(boolean) - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with only tokenToEndpointMap.
- cloneShallow() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- cloneWith(Iterable<CFMetaData>, UTMetaData) - Method in class org.apache.cassandra.config.KSMetaData
-
- cloneWithHigherVersion(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- cloneWithNewStart(DecoratedKey, Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will
be built at the target samplingLevel.
- cloneWithTableAdded(CFMetaData) - Method in class org.apache.cassandra.config.KSMetaData
-
- cloneWithTableRemoved(CFMetaData) - Method in class org.apache.cassandra.config.KSMetaData
-
- close() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- close() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- close() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- close() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
clean up any open resources
- close() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- close() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- close() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- close() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- close() - Method in class org.apache.cassandra.db.compaction.Verifier
-
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- close(Reporter) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- close(Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- close(Throwable) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- close() - Method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Closes this stream and frees resources associated with this stream.
- close(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- close() - Method in class org.apache.cassandra.io.util.Memory
-
- close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- close() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- close(Throwable) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- close() - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- close() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
-
- close() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- close() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
- close() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- close() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- close() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- close() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Closes the socket.
- close() - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- close() - Method in class org.apache.cassandra.tools.NodeProbe
-
- close() - Method in class org.apache.cassandra.transport.SimpleClient
-
- close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close(Throwable) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
To be called exactly once for each register() call this object is returned for, indicating the operation
is complete
- close() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- close() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- close(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- close() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- close(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- close() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- close() - Method in interface org.apache.cassandra.utils.IFilter
-
- close() - Method in class org.apache.cassandra.utils.MergeIterator
-
- close() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
May be overridden by implementations that require cleaning up after use
- close() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- close() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- close() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- close(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
-
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
-
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- closed - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- closeIncoming() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- closeOutgoing() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- CloudstackSnitch - Class in org.apache.cassandra.locator
-
A snitch that assumes a Cloudstack Zone follows the typical convention
<country>-<location>-<availability zone> and uses the country/location
tuple as a datacenter and the availability zone as a rack
- CloudstackSnitch() - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
-
- cluster_name - Variable in class org.apache.cassandra.config.Config
-
- clusteringColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- clusteringKeyDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- clusteringPrefixSize() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
The number of clustering columns for the table this is the type of.
- clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- clusteringRestrictionsNeedFiltering() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- clusteringSize() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- clusteringSize - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- clusteringSize() - Method in interface org.apache.cassandra.db.composites.CellName
-
The number of clustering components.
- clusteringSize() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- clusteringSize() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- clusteringSize() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- clusteringSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- clusteringType - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- CmdLineOptions() - Constructor for class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
- coalesce(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
Drain from the input blocking queue to the output list up to maxItems elements.
- coalesceInternal(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- CoalescingStrategies - Class in org.apache.cassandra.utils
-
- CoalescingStrategies() - Constructor for class org.apache.cassandra.utils.CoalescingStrategies
-
- CoalescingStrategies.Coalescable - Interface in org.apache.cassandra.utils
-
- CoalescingStrategies.CoalescingStrategy - Class in org.apache.cassandra.utils
-
- CoalescingStrategy(CoalescingStrategies.Parker, Logger, String) - Constructor for class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
-
- code() - Method in exception org.apache.cassandra.exceptions.CassandraException
-
- code() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception code.
- code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- code() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- code() - Method in exception org.apache.cassandra.transport.ServerError
-
- codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet
-
- Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- codec - Static variable in enum org.apache.cassandra.transport.DataType
-
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthChallenge
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
-
- codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.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<Cell>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateColumns(ColumnFamily, List<? extends Iterator<Cell>>, IDiskAtomFilter, DecoratedKey, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, IDiskAtomFilter, DecoratedKey, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, Iterator<? extends OnDiskAtom>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- CollationController - Class in org.apache.cassandra.db
-
- CollationController(ColumnFamilyStore, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
-
- Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
-
- collectionColumns(CellName, ColumnFamily, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- collectionCondition(Term.Raw, Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
A condition on a collection element.
- collectionElement() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- collectionElement() - Method in interface org.apache.cassandra.db.composites.CellName
-
The value of the collection element, or null if the cell is not part
of a collection (i.e.
- collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
-
- collectionElement() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- collectionElement() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- collectionInCondition(Term.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a collection element.
- collectionInCondition(Term.Raw, AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a collection element with a single marker.
- CollectionSerializer<T> - Class in org.apache.cassandra.serializers
-
- CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
-
- collectionType() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- collectionType() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
The type of the collections (or null if the type does not have any non-frozen collections).
- collectionType() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
-
- CollectionType<T> - Class in org.apache.cassandra.db.marshal
-
The abstract validator that is the base for maps, sets and lists (both frozen and non-frozen).
- CollectionType(CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
-
- CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Attributes
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.ColumnCondition
-
Collects the column specification for the bind variables of this operation.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Operation
-
Collects the column specification for the bind variables of this operation.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Term
-
Collects the column specification for the bind variables in this Term.
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
collects columns from reducedColumns into returnCF.
- collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- column - Variable in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- column - Variable in class org.apache.cassandra.cql3.ColumnCondition
-
- column - Variable in class org.apache.cassandra.cql3.Operation
-
- column - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- column - Variable in class org.apache.cassandra.db.IndexExpression
-
- column - Variable in class org.apache.cassandra.thrift.Cassandra.add_args
-
- column - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- Column - Class in org.apache.cassandra.thrift
-
Basic unit of data within a ColumnFamily.
- Column() - Constructor for class org.apache.cassandra.thrift.Column
-
- Column(ByteBuffer) - Constructor for class org.apache.cassandra.thrift.Column
-
- Column(Column) - Constructor for class org.apache.cassandra.thrift.Column
-
Performs a deep copy on other.
- column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- column - Variable in class org.apache.cassandra.thrift.ColumnPath
-
- Column._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- column_family - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- column_family - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- column_family - Variable in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- column_family - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- column_family - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- column_family - Variable in class org.apache.cassandra.thrift.ColumnParent
-
- column_family - Variable in class org.apache.cassandra.thrift.ColumnPath
-
- column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
-
- column_metadata - Variable in class org.apache.cassandra.thrift.CfDef
-
- column_name - Variable in class org.apache.cassandra.thrift.IndexExpression
-
- column_names - Variable in class org.apache.cassandra.thrift.SlicePredicate
-
- column_or_supercolumn - Variable in class org.apache.cassandra.thrift.Mutation
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.add_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- column_parent - Variable in class org.apache.cassandra.thrift.MultiSliceRequest
-
- column_path - Variable in class org.apache.cassandra.thrift.Cassandra.get_args
-
- column_path - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- column_predicate - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- column_slices - Variable in class org.apache.cassandra.thrift.MultiSliceRequest
-
- column_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- columnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- columnComparator(boolean) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- ColumnCondition - Class in org.apache.cassandra.cql3
-
A CQL3 condition on the value of a column or collection element.
- ColumnCondition.Bound - Class in org.apache.cassandra.cql3
-
- ColumnCondition.CollectionInBound - Class in org.apache.cassandra.cql3
-
- ColumnCondition.Raw - Class in org.apache.cassandra.cql3
-
- columnCount - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
how many columns are there in the row
- ColumnCounter - Class in org.apache.cassandra.db.filter
-
- ColumnCounter(long) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter
-
- columnCounter(CellNameType, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- columnCounter(CellNameType, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columnCounter(CellNameType, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- columnCounter() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- columnCounter() - Method in interface org.apache.cassandra.service.pager.SinglePartitionPager
-
- ColumnCounter.GroupByPrefix - Class in org.apache.cassandra.db.filter
-
- ColumnCounter.GroupByPrefixReversed - Class in org.apache.cassandra.db.filter
-
Similar to GroupByPrefix, but designed to handle counting cells in reverse order.
- columnDef - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
The definition of the column to which apply the restriction.
- columnDef - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- ColumnDef - Class in org.apache.cassandra.thrift
-
- ColumnDef() - Constructor for class org.apache.cassandra.thrift.ColumnDef
-
- ColumnDef(ByteBuffer, String) - Constructor for class org.apache.cassandra.thrift.ColumnDef
-
- ColumnDef(ColumnDef) - Constructor for class org.apache.cassandra.thrift.ColumnDef
-
Performs a deep copy on other.
- ColumnDef._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ColumnDefinition - Class in org.apache.cassandra.config
-
- ColumnDefinition(CFMetaData, ByteBuffer, AbstractType<?>, Integer, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition(String, String, ColumnIdentifier, AbstractType<?>, IndexType, Map<String, String>, String, Integer, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition.Kind - Enum in org.apache.cassandra.config
-
- columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
The columns to which the restriction apply.
- columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
The definition of the columns to which apply the token restriction.
- columnDefs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The column definitions which this index is responsible for
- ColumnDeletion(ColumnIdentifier.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ColumnDeletion
-
- COLUMNFAMILIES - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
-
- columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- COLUMNFAMILIES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- columnFamily - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- ColumnFamily - Class in org.apache.cassandra.db
-
A sorted map of columns.
- ColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.ColumnFamily
-
- columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
-
- columnFamily - Variable in class org.apache.cassandra.db.Truncation
-
- columnFamily - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
- ColumnFamily.Factory<T extends ColumnFamily> - Class in org.apache.cassandra.db
-
- ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
-
Deprecated.
- ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
Deprecated.
- ColumnFamilyMetrics - Class in org.apache.cassandra.metrics
-
- ColumnFamilyMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- ColumnFamilyMetrics.ColumnFamilyHistogram - Class in org.apache.cassandra.metrics
-
- ColumnFamilyMetrics.Sampler - Enum in org.apache.cassandra.metrics
-
- ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
-
Deprecated.
- ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
-
Deprecated.
- ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- ColumnFamilyRecordReader.Column - Class in org.apache.cassandra.hadoop
-
Deprecated.
- 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(Keyspace, String, IPartitioner, int, CFMetaData, Directories, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
-
- ColumnFamilyStore(Keyspace, String, IPartitioner, int, CFMetaData, Directories, boolean, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
-
- ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.FlushLargestColumnFamily - Class in org.apache.cassandra.db
-
Finds the largest memtable, as a percentage of *either* on- or off-heap memory limits, and immediately
queues it for flushing.
- ColumnFamilyStore.RefViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
-
The MBean interface for ColumnFamilyStore
- ColumnFamilyType - Enum in org.apache.cassandra.db
-
column family type enum
- columnFilter - Variable in class org.apache.cassandra.db.DataRange
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
-
Returns a column filter that should be used for a particular row key.
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- ColumnIdentifier - Class in org.apache.cassandra.cql3
-
Represents an identifer for a CQL column definition.
- ColumnIdentifier(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier(ByteBuffer, String) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier.Raw - Class in org.apache.cassandra.cql3
-
Because Thrift-created tables may have a non-text comparator, we cannot determine the proper 'key' until
we know the comparator.
- ColumnIndex - Class in org.apache.cassandra.db
-
- ColumnIndex.Builder - Class in org.apache.cassandra.db
-
Help to create an index for a column family based on size of columns,
and write said columns to disk.
- columnName - Variable in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- ColumnNameHelper - Class in org.apache.cassandra.io.sstable
-
- ColumnNameHelper() - Constructor for class org.apache.cassandra.io.sstable.ColumnNameHelper
-
- ColumnOrSuperColumn - Class in org.apache.cassandra.thrift
-
Methods for fetching rows/records from Cassandra will return either a single instance of ColumnOrSuperColumn or a list
of ColumnOrSuperColumns (get_slice()).
- ColumnOrSuperColumn() - Constructor for class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- ColumnOrSuperColumn(ColumnOrSuperColumn) - Constructor for class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Performs a deep copy on other.
- ColumnOrSuperColumn._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ColumnParent - Class in org.apache.cassandra.thrift
-
ColumnParent is used when selecting groups of columns from the same ColumnFamily.
- ColumnParent() - Constructor for class org.apache.cassandra.thrift.ColumnParent
-
- ColumnParent(String) - Constructor for class org.apache.cassandra.thrift.ColumnParent
-
- ColumnParent(ColumnParent) - Constructor for class org.apache.cassandra.thrift.ColumnParent
-
Performs a deep copy on other.
- ColumnParent._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ColumnPath - Class in org.apache.cassandra.thrift
-
The ColumnPath is the path to a single column in Cassandra.
- ColumnPath() - Constructor for class org.apache.cassandra.thrift.ColumnPath
-
- ColumnPath(String) - Constructor for class org.apache.cassandra.thrift.ColumnPath
-
- ColumnPath(ColumnPath) - Constructor for class org.apache.cassandra.thrift.ColumnPath
-
Performs a deep copy on other.
- ColumnPath._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- columnReverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- columnReverseComparator() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- columns - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
-
- columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columns - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- COLUMNS - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
-
- columns - Variable in class org.apache.cassandra.thrift.CounterSuperColumn
-
- columns - Variable in class org.apache.cassandra.thrift.CqlRow
-
- columns - Variable in class org.apache.cassandra.thrift.KeySlice
-
- columns - Variable in class org.apache.cassandra.thrift.SuperColumn
-
- ColumnSerializer - Class in org.apache.cassandra.db
-
- ColumnSerializer(CellNameType) - Constructor for class org.apache.cassandra.db.ColumnSerializer
-
- columnSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- columnSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- ColumnSerializer.CorruptColumnException - Exception in org.apache.cassandra.db
-
- ColumnSerializer.Flag - Enum in org.apache.cassandra.db
-
Flag affecting deserialization behavior.
- columnsIndex - Variable in class org.apache.cassandra.db.ColumnIndex
-
- columnsIndex() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- ColumnSlice - Class in org.apache.cassandra.db.filter
-
- ColumnSlice(Composite, Composite) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice
-
- ColumnSlice - Class in org.apache.cassandra.thrift
-
The ColumnSlice is used to select a set of columns from inside a row.
- ColumnSlice() - Constructor for class org.apache.cassandra.thrift.ColumnSlice
-
- ColumnSlice(ColumnSlice) - Constructor for class org.apache.cassandra.thrift.ColumnSlice
-
Performs a deep copy on other.
- ColumnSlice._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ColumnSlice.Serializer - Class in org.apache.cassandra.db.filter
-
- ColumnSpecification - Class in org.apache.cassandra.cql3
-
- ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
-
- columnStats - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- ColumnStats - Class in org.apache.cassandra.io.sstable
-
ColumnStats holds information about the columns for one row inside sstable
- ColumnStats(int, long, long, int, StreamingHistogram, List<ByteBuffer>, List<ByteBuffer>, boolean) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats
-
- ColumnStats.MaxIntTracker - Class in org.apache.cassandra.io.sstable
-
- ColumnStats.MaxLongTracker - Class in org.apache.cassandra.io.sstable
-
- ColumnStats.MinLongTracker - Class in org.apache.cassandra.io.sstable
-
- ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
-
- columnToTuple(ColumnFamilyRecordReader.Column, CfDef, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
convert a column to a tuple
- colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Column update time delta on this CF
- colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Column update time delta on this Keyspace
- command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- commands - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- commandType - Variable in class org.apache.cassandra.db.ReadCommand
-
- comment(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- comment - Variable in class org.apache.cassandra.thrift.CfDef
-
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- commit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- Commit - Class in org.apache.cassandra.service.paxos
-
- Commit(ByteBuffer, UUID, ColumnFamily) - Constructor for class org.apache.cassandra.service.paxos.Commit
-
- commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- commit() - Method in interface org.apache.cassandra.utils.BatchRemoveIterator
-
Commits the remove operations in this batch iterator.
- commit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
commit any effects of this transaction object graph, then cleanup; delegates first to doCommit, then to doCleanup
- commit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- commit(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
-
- commit() - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
-
- Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
-
- commit_consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- commit_failure_policy - Variable in class org.apache.cassandra.config.Config
-
- CommitLog - Class in org.apache.cassandra.db.commitlog
-
- CommitLog.Configuration - Class in org.apache.cassandra.db.commitlog
-
- commitlog_compression - Variable in class org.apache.cassandra.config.Config
-
- commitlog_directory - Variable in class org.apache.cassandra.config.Config
-
- commitlog_max_compression_buffers_in_pool - Variable in class org.apache.cassandra.config.Config
-
- commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- commitlog_segment_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
-
- CommitLogArchiver(String, String, String, long, TimeUnit) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
-
- CommitLogDescriptor(int, long, ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogDescriptor(long, ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- commitLogLowerBound - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogLowerBound(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogLowerBound - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogMetrics - Class in org.apache.cassandra.metrics
-
Metrics for commit log
- CommitLogMetrics() - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
-
- CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer.CommitLogReplayException - Exception in org.apache.cassandra.db.commitlog
-
- CommitLogReplayException(String, Throwable) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
-
- CommitLogReplayException(String) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
-
- CommitLogSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- CommitLogSegmentManager - Class in org.apache.cassandra.db.commitlog
-
Performs eager-creation of commit log segments in a background thread.
- commitLogUpperBound - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogUpperBound(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- commitLogUpperBound - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
Deprecated.
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- CommitVerbHandler - Class in org.apache.cassandra.service.paxos
-
- CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- compact() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- Compact - Class in org.apache.cassandra.tools.nodetool
-
- Compact() - Constructor for class org.apache.cassandra.tools.nodetool.Compact
-
- CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
-
- CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- compacting - Variable in class org.apache.cassandra.db.lifecycle.View
-
- COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- COMPACTION_HISTORY - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- compaction_large_partition_warning_threshold_mb - Variable in class org.apache.cassandra.config.Config
-
- compaction_strategy - Variable in class org.apache.cassandra.thrift.CfDef
-
- COMPACTION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- compaction_strategy_options - Variable in class org.apache.cassandra.thrift.CfDef
-
- compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
-
- CompactionAwareWriter - Class in org.apache.cassandra.db.compaction.writers
-
Class that abstracts away the actual writing of files to make it possible to use CompactionTask for more
use cases.
- CompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- CompactionCandidate(Collection<SSTableReader>, int, long) - Constructor for class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- CompactionController - Class in org.apache.cassandra.db.compaction
-
Manage compaction options.
- CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionHistory - Class in org.apache.cassandra.tools.nodetool
-
- CompactionHistory() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionHistory
-
- CompactionHistoryTabularData - Class in org.apache.cassandra.db.compaction
-
- CompactionHistoryTabularData() - Constructor for class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- compactionId - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- compactionId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo - Class in org.apache.cassandra.db.compaction
-
Implements serializable to allow structured info to be returned via JMX.
- CompactionInfo(CFMetaData, OperationType, long, long, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(OperationType, long, long, String, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(CFMetaData, OperationType, long, long, String, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException - Exception in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException(CompactionInfo) - Constructor for exception org.apache.cassandra.db.compaction.CompactionInterruptedException
-
- CompactionIterable - Class in org.apache.cassandra.db.compaction
-
- CompactionIterable(OperationType, List<ISSTableScanner>, CompactionController, SSTableFormat.Type, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
-
- CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
-
- CompactionManager - Class in org.apache.cassandra.db.compaction
-
A singleton which manages a private executor of ongoing compactions.
- CompactionManager() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager
-
- CompactionManager.AllSSTableOpStatus - Enum in org.apache.cassandra.db.compaction
-
- CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
-
- CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
-
- CompactionMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
Compaction related SSTable metadata.
- CompactionMetadata(Set<Integer>, ICardinality) - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- CompactionMetadata.CompactionMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
- CompactionMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- CompactionMetrics - Class in org.apache.cassandra.metrics
-
Metrics for compaction.
- CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
-
- COMPACTIONS_IN_PROGRESS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- CompactionStats - Class in org.apache.cassandra.tools.nodetool
-
- CompactionStats() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionStats
-
- compactionStrategyClass - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyClass(Class<? extends AbstractCompactionStrategy>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
-
- CompactionTask - Class in org.apache.cassandra.db.compaction
-
- CompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
- compactionType - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- compactionType - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- compactValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- compactValueDef(CFMetaData, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- comparator - 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.DecoratedKey
-
- comparator - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- comparator - Variable in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparator_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
-
- compare(Composite, Composite) - Method in interface org.apache.cassandra.db.composites.CType
-
- compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- 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
-
Deprecated.
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ListType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.MapType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SetType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- compare(SSTableReader, SSTableReader) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.SizeComparator
-
- compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compareAsymmetric(T1, T2) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
-
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- 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
-
- compareIntegers(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.IntegerType
-
- compareLongs(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.LongType
-
- compareMaps(AbstractType<?>, AbstractType<?>, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- compareNextTo(Composite) - Method in class org.apache.cassandra.db.AtomDeserializer
-
Compare the provided composite to the next atom to read on disk.
- compareNextTo(Composite) - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
-
Compare the next name to read to the provided Composite.
- compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Compare two ByteBuffer at specified offsets for length.
- compareTo(FunctionResource) - Method in class org.apache.cassandra.auth.FunctionResource
-
- compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
-
- compareTo(RoleResource) - Method in class org.apache.cassandra.auth.RoleResource
-
- compareTo(Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- compareTo(RowPosition) - Method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(IPartitioner, ByteBuffer, RowPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Note: this class has a natural ordering that is inconsistent with equals
- compareTo(RowPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
-
- compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
-
- compareTo(MetadataComponent) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
-
- compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- compareTo(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- compareTo(AuthenticationException) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- compareTo(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- compareTo(AuthorizationException) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- compareTo(CASResult) - Method in class org.apache.cassandra.thrift.CASResult
-
- compareTo(Cassandra.add_args) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- compareTo(Cassandra.add_result) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- compareTo(Cassandra.atomic_batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- compareTo(Cassandra.atomic_batch_mutate_result) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- compareTo(Cassandra.batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- compareTo(Cassandra.batch_mutate_result) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- compareTo(Cassandra.cas_args) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- compareTo(Cassandra.cas_result) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- compareTo(Cassandra.describe_cluster_name_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- compareTo(Cassandra.describe_cluster_name_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- compareTo(Cassandra.describe_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- compareTo(Cassandra.describe_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- compareTo(Cassandra.describe_keyspaces_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- compareTo(Cassandra.describe_keyspaces_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- compareTo(Cassandra.describe_local_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- compareTo(Cassandra.describe_local_ring_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- compareTo(Cassandra.describe_partitioner_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- compareTo(Cassandra.describe_partitioner_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- compareTo(Cassandra.describe_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- compareTo(Cassandra.describe_ring_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- compareTo(Cassandra.describe_schema_versions_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- compareTo(Cassandra.describe_schema_versions_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- compareTo(Cassandra.describe_snitch_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- compareTo(Cassandra.describe_snitch_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- compareTo(Cassandra.describe_splits_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- compareTo(Cassandra.describe_splits_ex_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- compareTo(Cassandra.describe_splits_ex_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- compareTo(Cassandra.describe_splits_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- compareTo(Cassandra.describe_token_map_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- compareTo(Cassandra.describe_token_map_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- compareTo(Cassandra.describe_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- compareTo(Cassandra.describe_version_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- compareTo(Cassandra.execute_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- compareTo(Cassandra.execute_cql3_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- compareTo(Cassandra.execute_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- compareTo(Cassandra.execute_cql_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- compareTo(Cassandra.execute_prepared_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- compareTo(Cassandra.execute_prepared_cql3_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- compareTo(Cassandra.execute_prepared_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- compareTo(Cassandra.execute_prepared_cql_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- compareTo(Cassandra.get_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- compareTo(Cassandra.get_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- compareTo(Cassandra.get_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- compareTo(Cassandra.get_indexed_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- compareTo(Cassandra.get_indexed_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- compareTo(Cassandra.get_multi_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- compareTo(Cassandra.get_multi_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- compareTo(Cassandra.get_paged_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- compareTo(Cassandra.get_paged_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- compareTo(Cassandra.get_range_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- compareTo(Cassandra.get_range_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- compareTo(Cassandra.get_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- compareTo(Cassandra.get_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- compareTo(Cassandra.get_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- compareTo(Cassandra.insert_args) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- compareTo(Cassandra.insert_result) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- compareTo(Cassandra.login_args) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- compareTo(Cassandra.login_result) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- compareTo(Cassandra.multiget_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- compareTo(Cassandra.multiget_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- compareTo(Cassandra.multiget_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- compareTo(Cassandra.multiget_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- compareTo(Cassandra.prepare_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- compareTo(Cassandra.prepare_cql3_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- compareTo(Cassandra.prepare_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- compareTo(Cassandra.prepare_cql_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- compareTo(Cassandra.remove_args) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- compareTo(Cassandra.remove_counter_args) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- compareTo(Cassandra.remove_counter_result) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- compareTo(Cassandra.remove_result) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- compareTo(Cassandra.set_cql_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- compareTo(Cassandra.set_cql_version_result) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- compareTo(Cassandra.set_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- compareTo(Cassandra.set_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- compareTo(Cassandra.system_add_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- compareTo(Cassandra.system_add_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- compareTo(Cassandra.system_add_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- compareTo(Cassandra.system_add_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- compareTo(Cassandra.system_drop_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- compareTo(Cassandra.system_drop_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- compareTo(Cassandra.system_drop_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- compareTo(Cassandra.system_drop_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- compareTo(Cassandra.system_update_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- compareTo(Cassandra.system_update_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- compareTo(Cassandra.system_update_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- compareTo(Cassandra.system_update_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- compareTo(Cassandra.trace_next_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- compareTo(Cassandra.trace_next_query_result) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- compareTo(Cassandra.truncate_args) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- compareTo(Cassandra.truncate_result) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- compareTo(CfDef) - Method in class org.apache.cassandra.thrift.CfDef
-
- compareTo(CfSplit) - Method in class org.apache.cassandra.thrift.CfSplit
-
- compareTo(Column) - Method in class org.apache.cassandra.thrift.Column
-
- compareTo(ColumnDef) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- compareTo(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- compareTo(ColumnParent) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- compareTo(ColumnPath) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- compareTo(ColumnSlice) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- compareTo(CounterColumn) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- compareTo(CounterSuperColumn) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- compareTo(CqlMetadata) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- compareTo(CqlPreparedResult) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- compareTo(CqlResult) - Method in class org.apache.cassandra.thrift.CqlResult
-
- compareTo(CqlRow) - Method in class org.apache.cassandra.thrift.CqlRow
-
- compareTo(Deletion) - Method in class org.apache.cassandra.thrift.Deletion
-
- compareTo(EndpointDetails) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- compareTo(IndexClause) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- compareTo(IndexExpression) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- compareTo(InvalidRequestException) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- compareTo(KeyCount) - Method in class org.apache.cassandra.thrift.KeyCount
-
- compareTo(KeyRange) - Method in class org.apache.cassandra.thrift.KeyRange
-
- compareTo(KeySlice) - Method in class org.apache.cassandra.thrift.KeySlice
-
- compareTo(KsDef) - Method in class org.apache.cassandra.thrift.KsDef
-
- compareTo(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- compareTo(Mutation) - Method in class org.apache.cassandra.thrift.Mutation
-
- compareTo(NotFoundException) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- compareTo(SchemaDisagreementException) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- compareTo(SlicePredicate) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- compareTo(SliceRange) - Method in class org.apache.cassandra.thrift.SliceRange
-
- compareTo(SuperColumn) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- compareTo(TimedOutException) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- compareTo(TokenRange) - Method in class org.apache.cassandra.thrift.TokenRange
-
- compareTo(TriggerDef) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- compareTo(UnavailableException) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- compareTo(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
-
- compareTo(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- compareTo(CounterId) - Method in class org.apache.cassandra.utils.CounterId
-
- compareTo(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compareTo(Object, long, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- compareTo(Object, long, int, Object, long, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
Lexicographically compare two arrays.
- compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
-
- compareToSimple(Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compareUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
Lexicographically compare two byte arrays.
- compareUnsigned(ByteBuffer, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(byte[], int, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compareWithOperator(Operator, AbstractType<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
Returns true if the operator is satisfied (i.e.
- compile(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
-
- complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
- complete(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- complete(String, long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- complete() - Method in class org.apache.cassandra.repair.Validator
-
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
- complete() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- complete() - Method in class org.apache.cassandra.streaming.StreamSession
-
Check if session is completed on receiving StreamMessage.Type.COMPLETE
message.
- complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for file at sequenceNumber
.
- completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Number of completed tasks
- completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Number of completed compactions since server [re]start
- completedTasks - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of completed tasks.
- completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of completed tasks.
- CompleteMessage - Class in org.apache.cassandra.streaming.messages
-
- CompleteMessage() - Constructor for class org.apache.cassandra.streaming.messages.CompleteMessage
-
- completeSetup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- completeTree() - Method in class org.apache.cassandra.repair.Validator
-
- Component - Class in org.apache.cassandra.io.sstable
-
SSTables are made up of multiple components in separate files.
- Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component(Component.Type, String) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component.Type - Enum in org.apache.cassandra.io.sstable
-
- componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- components - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- componentsCount() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
The number of subcomponents this type has.
- componentsCount() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- componentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Discovers existing components for the descriptor.
- componentSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.Tuples
-
- compose(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
Used by UDF implementations (both Java code generated by
JavaSourceUDFFactory
and script executor
ScriptBasedUDF
) to convert the C*
serialized representation to the Java object representation.
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- compose_boolean(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_byte(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_double(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_float(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_int(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_long(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- compose_short(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
Deconstructs a composite type to a Tuple.
- Composite - Interface in org.apache.cassandra.db.composites
-
A composite value.
- Composite.EOC - Enum in org.apache.cassandra.db.composites
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- CompositeComponent(AbstractType<?>, ByteBuffer) - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- compositeDense(ByteBuffer...) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- Composites - Class in org.apache.cassandra.db.composites
-
- CompositesBuilder - Class in org.apache.cassandra.db.composites
-
Builder that allow to build multiple composites at the same time.
- CompositesBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.CompositesBuilder
-
- 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
-
- CompositesIndexIncludingCollectionKey - Class in org.apache.cassandra.db.index.composites
-
Common superclass for indexes that capture collection keys, including
indexes on such keys themselves.
- CompositesIndexIncludingCollectionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
-
- CompositesIndexOnClusteringKey - Class in org.apache.cassandra.db.index.composites
-
Index on a CLUSTERING_COLUMN column definition.
- CompositesIndexOnClusteringKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- CompositesIndexOnCollectionKey - Class in org.apache.cassandra.db.index.composites
-
Index on the collection element of the cell name of a collection.
- CompositesIndexOnCollectionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- CompositesIndexOnCollectionKeyAndValue - Class in org.apache.cassandra.db.index.composites
-
Index on the element and value of cells participating in a collection.
- CompositesIndexOnCollectionKeyAndValue() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
-
- CompositesIndexOnCollectionValue - Class in org.apache.cassandra.db.index.composites
-
Index the value of a collection cell.
- CompositesIndexOnCollectionValue() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- CompositesIndexOnPartitionKey - Class in org.apache.cassandra.db.index.composites
-
Index on a PARTITION_KEY column definition.
- CompositesIndexOnPartitionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- CompositesIndexOnRegular - Class in org.apache.cassandra.db.index.composites
-
Index on a REGULAR column definition on a composite type.
- CompositesIndexOnRegular() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- compositeSparse(ByteBuffer[], ColumnIdentifier, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- compositeSparseWithCollection(ByteBuffer[], ByteBuffer, ColumnIdentifier, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- CompositesSearcher - Class in org.apache.cassandra.db.index.composites
-
- CompositesSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.composites.CompositesSearcher
-
- compositesToGroup - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- CompositeType - Class in org.apache.cassandra.db.marshal
-
- CompositeType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.CompositeType
-
- CompositeType.Builder - Class in org.apache.cassandra.db.marshal
-
- CompoundCBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
-
- CompoundComposite - Class in org.apache.cassandra.db.composites
-
A "truly-composite" Composite.
- CompoundCType - Class in org.apache.cassandra.db.composites
-
A truly-composite CType.
- CompoundCType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundCType
-
- CompoundCType.CompoundCBuilder - Class in org.apache.cassandra.db.composites
-
- CompoundDenseCellName - Class in org.apache.cassandra.db.composites
-
- CompoundDenseCellNameType - Class in org.apache.cassandra.db.composites
-
- CompoundDenseCellNameType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- CompoundSparseCellName - Class in org.apache.cassandra.db.composites
-
- CompoundSparseCellName.WithCollection - Class in org.apache.cassandra.db.composites
-
- CompoundSparseCellNameType - Class in org.apache.cassandra.db.composites
-
- CompoundSparseCellNameType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- CompoundSparseCellNameType(List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- CompoundSparseCellNameType.WithCollection - Class in org.apache.cassandra.db.composites
-
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
Compression for ByteBuffers.
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- compress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- compressArray(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
-
- CompressedInputStream - Class in org.apache.cassandra.streaming.compress
-
InputStream which reads data from underlining source with given
CompressionInfo
.
- CompressedInputStream(InputStream, CompressionInfo) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- CompressedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile.Cleanup - Class in org.apache.cassandra.io.util
-
- CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
-
CRAR extends RAR to transparently uncompress blocks from the file into RAR.buffer.
- CompressedRandomAccessReader(ChannelProxy, CompressionMetadata, ICompressedFile, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- CompressedSegment - Class in org.apache.cassandra.db.commitlog
-
- CompressedSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- CompressedSegmentedFile(ChannelProxy, CompressionMetadata, TreeMap<Long, MappedByteBuffer>) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
-
- CompressedSequentialWriter(File, String, CompressionParameters, MetadataCollector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
-
Class to hold a mark to the position of the file
- CompressedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.compress
-
- CompressedStreamReader - Class in org.apache.cassandra.streaming.compress
-
StreamReader that reads from streamed compressed SSTable
- CompressedStreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressedStreamWriter - Class in org.apache.cassandra.streaming.compress
-
StreamWriter for compressed SSTable.
- CompressedStreamWriter(SSTableReader, Collection<Pair<Long, Long>>, CompressionInfo, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- CompressedThrottledReader - Class in org.apache.cassandra.io.compress
-
- CompressedThrottledReader(ChannelProxy, CompressionMetadata, ICompressedFile, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- compression - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- compression - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- compression - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- compression - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- compression - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- Compression - Enum in org.apache.cassandra.thrift
-
CQL query compression
- COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
-
- compression_options - Variable in class org.apache.cassandra.thrift.CfDef
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressionInfo - Class in org.apache.cassandra.streaming.compress
-
Container that carries compression parameters and chunks to decompress data from stream.
- CompressionInfo(CompressionMetadata.Chunk[], CompressionParameters) - Constructor for class org.apache.cassandra.streaming.compress.CompressionInfo
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
Compression info for SSTable to send.
- CompressionMetadata - Class in org.apache.cassandra.io.compress
-
Holds metadata about compressed file
- CompressionMetadata.Chunk - Class in org.apache.cassandra.io.compress
-
Holds offset and length of the file chunk
- CompressionMetadata.Writer - Class in org.apache.cassandra.io.compress
-
- compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Off heap memory used by compression meta data
- compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Off heap memory used by compression meta data
- compressionParameters - Variable in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters(CompressionParameters) - Method in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters() - Method in class org.apache.cassandra.config.CFMetaData
-
- CompressionParameters - Class in org.apache.cassandra.io.compress
-
- CompressionParameters(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- compressionRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Current compression ratio for all SSTables
- compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- Compressor() - Constructor for class org.apache.cassandra.transport.Frame.Compressor
-
- compute(int) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Computes and returns the aggregate current value.
- compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- computeBloomSpec(int) - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Given the number of buckets that can be used per element, return a
specification that minimizes the false positive rate.
- computeBloomSpec(int, double) - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Given a maximum tolerable false positive probability, compute a Bloom
specification which will give less than the specified false positive rate,
but minimize the number of buckets per element and the number of hash
functions used.
- 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.io.sstable.format.big.BigTableScanner.KeyScanningIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
Find the next TreeRange.
- concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- concurrent_compactors - Variable in class org.apache.cassandra.config.Config
-
- concurrent_counter_writes - Variable in class org.apache.cassandra.config.Config
-
- concurrent_reads - Variable in class org.apache.cassandra.config.Config
-
- concurrent_replicates - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- concurrent_writes - Variable in class org.apache.cassandra.config.Config
-
- ConcurrentBiMap<K,V> - Class in org.apache.cassandra.utils
-
A variant of BiMap that permits concurrent access, and expects uniqueness of values in both domain and range.
- ConcurrentBiMap() - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
-
- ConcurrentBiMap(Map<K, V>, Map<V, K>) - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
-
- ConcurrentLinkedHashCache<K extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
-
Wrapper so CLHM can implement ICache interface.
- condition(ColumnDefinition, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- condition(ColumnDefinition, Term, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- conditionNotMet - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- conditions - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- conf - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- conf - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- conf - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- conf - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- Config - Class in org.apache.cassandra.config
-
A class that contains configuration properties for the cassandra node it runs within.
- Config() - Constructor for class org.apache.cassandra.config.Config
-
- Config.CommitFailurePolicy - Enum in org.apache.cassandra.config
-
- Config.CommitLogSync - Enum in org.apache.cassandra.config
-
- Config.DiskAccessMode - Enum in org.apache.cassandra.config
-
- Config.DiskFailurePolicy - Enum in org.apache.cassandra.config
-
- Config.InternodeCompression - Enum in org.apache.cassandra.config
-
- Config.MemtableAllocationType - Enum in org.apache.cassandra.config
-
- Config.RequestSchedulerId - Enum in org.apache.cassandra.config
-
- ConfigHelper - Class in org.apache.cassandra.hadoop
-
- ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
-
- configHintedHandoff() - Method in class org.apache.cassandra.config.Config
-
- configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- Configuration(ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
- ConfigurationException - Exception in org.apache.cassandra.exceptions
-
- ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, boolean) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationLoader - Interface in org.apache.cassandra.config
-
- confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- connectAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- connecting - Variable in class org.apache.cassandra.streaming.SessionInfo
-
- connecting - Variable in class org.apache.cassandra.streaming.StreamSession
-
Actual connecting address.
- Connection - Class in org.apache.cassandra.transport
-
- Connection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
-
- connection - Variable in class org.apache.cassandra.transport.Message
-
- connection() - Method in class org.apache.cassandra.transport.Message
-
- connection - Variable in class org.apache.cassandra.transport.SimpleClient
-
- Connection.Factory - Interface in org.apache.cassandra.transport
-
- Connection.Tracker - Interface in org.apache.cassandra.transport
-
- connectionComplete(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
The connection associated with @param socket is permanently finished.
- connectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Set custom StreamConnectionFactory to be used for establishing connection
- ConnectionHandler - Class in org.apache.cassandra.streaming
-
ConnectionHandler manages incoming/outgoing message exchange for the
StreamSession
.
- ConnectionMetrics - Class in org.apache.cassandra.metrics
-
- ConnectionMetrics(InetAddress, OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.metrics.ConnectionMetrics
-
Create metrics for given connection pool.
- connections - Variable in class org.apache.cassandra.net.MessagingService.SocketThread
-
- ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
-
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- consistency - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- consistency - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.add_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- consistency_level - Variable in class org.apache.cassandra.thrift.MultiSliceRequest
-
- consistencyForRole(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
-
- ConsistencyLevel - Enum in org.apache.cassandra.db
-
- consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- ConsistencyLevel - Enum in org.apache.cassandra.thrift
-
The ConsistencyLevel is an enum that controls both read and write
behavior based on the ReplicationFactor of the keyspace.
- CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- Constants - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for constants.
- Constants() - Constructor for class org.apache.cassandra.cql3.Constants
-
- Constants.Adder - Class in org.apache.cassandra.cql3
-
- Constants.Deleter - Class in org.apache.cassandra.cql3
-
- Constants.Literal - Class in org.apache.cassandra.cql3
-
- Constants.Marker - Class in org.apache.cassandra.cql3
-
- Constants.Setter - Class in org.apache.cassandra.cql3
-
- Constants.Substracter - Class in org.apache.cassandra.cql3
-
- Constants.Type - Enum in org.apache.cassandra.cql3
-
- Constants.Value - Class in org.apache.cassandra.cql3
-
A constant value, i.e.
- construct(Cell) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- construct() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- construct(CommitLog) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- construct(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- construct(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Constructs an instance of the given class, which must have a no-arg or default constructor.
- Contains(ColumnDefinition, Term, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- Contains(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- contains(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Check to see if a certain ReplayPosition is contained by this segment file.
- contains(RowPosition) - Method in class org.apache.cassandra.db.DataRange
-
- contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.Bounds
-
- contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
-
- contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- contains(T) - Method in class org.apache.cassandra.dht.Range
-
Helps determine if a given point on the DHT ring is contained
in the range in question.
- contains(Token) - Method in class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
-
Returns true if the ranges given in the constructor contains the token, false otherwise.
- contains(String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
- contains(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- containsACollection() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains a collection.
- containsAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- containsBindMarker() - Method in interface org.apache.cassandra.cql3.Term
-
Whether or not that term contains at least one bind marker.
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- containsCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- containsKey(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- containsKey(K) - Method in interface org.apache.cassandra.cache.ICache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- containsNull() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
-
Checks if the composites contains null elements.
- containsOnlyStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains only static columns.
- 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
-
- containsStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
Checks if this selection contains static columns.
- containsTriggerDefinition(TriggerDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- containsUnset() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
-
Checks if the composites contains unset elements.
- containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsValue(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- contention - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- contents() - Method in class org.apache.cassandra.db.Memtable
-
- contentSerializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- contentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- context - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- context - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- ContextAllocator - Class in org.apache.cassandra.utils.memory
-
Wraps calls to a PoolAllocator with the provided writeOp.
- ContextAllocator(OpOrder.Group, MemtableBufferAllocator) - Constructor for class org.apache.cassandra.utils.memory.ContextAllocator
-
- contextManager - Static variable in interface org.apache.cassandra.db.CounterCell
-
- controller - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- controller - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- convert(long) - Static method in class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
-
- convertSchemaToMutations() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is part of IFailureDetectionEventListener interface.
- convict(InetAddress, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
-
Convict the specified endpoint.
- convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
called from gossiper when it notices a node is not responding.
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.AnticompactionTask
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.RepairSession
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Something has happened to a remote node - if that node is a coordinator, we mark the parent repair session id as failed.
- coordinator - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- coordinator - Variable in class org.apache.cassandra.tracing.TraceState
-
- coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- coordinatorScanLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- copy(long) - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- copy() - Method in class org.apache.cassandra.config.CFMetaData
-
- copy(UUID) - Method in class org.apache.cassandra.config.CFMetaData
-
Clones the CFMetaData, but sets a different cfId
- copy() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
-
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.BoundedComposite
-
- copy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.composites.CellName
-
- copy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.composites.Composite
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundComposite
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleComposite
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleSparseInternedCellName
-
- copy() - Method in class org.apache.cassandra.db.DeletionInfo
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.DeletionInfo
-
- copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- copy() - Method in class org.apache.cassandra.db.Mutation
-
- copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy(AbstractAllocator) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy() - Method in class org.apache.cassandra.db.ReadCommand
-
- copy() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- copy(long) - Method in class org.apache.cassandra.io.util.Memory
-
- copy(long) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- copy(ByteBuffer, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
-
- copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(Object, long, Object, long, long) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
- copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
-
- copyOpts(CFMetaData, CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
-
- copyReadableBounds() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- copyReadableBounds() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
Retrieve the readable bounds if any so they can be cloned into other files such
as when downsampling an index summary.
- copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- copyTo(DataInput, OutputStream, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- CorruptBlockException - Exception in org.apache.cassandra.io.compress
-
- CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, CompressionMetadata.Chunk, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptColumnException(String) - Constructor for exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- CorruptFileException(Exception, File) - Constructor for exception org.apache.cassandra.io.util.ChecksummedRandomAccessReader.CorruptFileException
-
- 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 - Variable in class org.apache.cassandra.db.ClockAndCount
-
- count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
- count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
-
- count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The total number of bytes initially available in the byte array
buf
.
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- count() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
The total number of events that have occurred since this object was created.
- count - Variable in class org.apache.cassandra.thrift.CqlPreparedResult
-
- count - Variable in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- count - Variable in class org.apache.cassandra.thrift.KeyCount
-
- count - Variable in class org.apache.cassandra.thrift.KeyRange
-
- count - Variable in class org.apache.cassandra.thrift.MultiSliceRequest
-
- count - Variable in class org.apache.cassandra.thrift.SliceRange
-
- count() - Method in class org.apache.cassandra.utils.btree.Cursor
-
- 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.
- countColumn(Cell) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- countCQL3Rows() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- countCQL3Rows(CellNameType) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- countCQL3Rows(CellNameType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- countCQL3Rows(CellNameType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- countCQL3Rows - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- counter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- counter_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- counter_cache_save_period - Variable in class org.apache.cassandra.config.Config
-
- counter_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- counter_column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- COUNTER_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- counter_super_column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- counter_write_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- counterCache - Variable in class org.apache.cassandra.service.CacheService
-
- CounterCacheKey - Class in org.apache.cassandra.cache
-
- CounterCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.CounterCacheSerializer
-
- CounterCell - Interface in org.apache.cassandra.db
-
A column that represents a partitioned counter.
- CounterColumn - Class in org.apache.cassandra.thrift
-
- CounterColumn() - Constructor for class org.apache.cassandra.thrift.CounterColumn
-
- CounterColumn(ByteBuffer, long) - Constructor for class org.apache.cassandra.thrift.CounterColumn
-
- CounterColumn(CounterColumn) - Constructor for class org.apache.cassandra.thrift.CounterColumn
-
Performs a deep copy on other.
- CounterColumn._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CounterColumnType - Class in org.apache.cassandra.db.marshal
-
- CounterContext - Class in org.apache.cassandra.db.context
-
An implementation of a partitioned counter context.
- CounterContext() - Constructor for class org.apache.cassandra.db.context.CounterContext
-
- CounterContext.ContextState - Class in org.apache.cassandra.db.context
-
Helper class to work on contexts (works by iterating over them).
- CounterContext.Relationship - Enum in org.apache.cassandra.db.context
-
- counterid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- CounterId - Class in org.apache.cassandra.utils
-
- CounterMutation - Class in org.apache.cassandra.db
-
- CounterMutation(Mutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
-
- CounterMutation.CounterMutationSerializer - Class in org.apache.cassandra.db
-
- CounterMutationSerializer() - Constructor for class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
-
- CounterMutationVerbHandler - Class in org.apache.cassandra.db
-
- CounterMutationVerbHandler() - Constructor for class org.apache.cassandra.db.CounterMutationVerbHandler
-
- CounterSerializer - Class in org.apache.cassandra.serializers
-
- CounterSerializer() - Constructor for class org.apache.cassandra.serializers.CounterSerializer
-
- CounterSuperColumn - Class in org.apache.cassandra.thrift
-
- CounterSuperColumn() - Constructor for class org.apache.cassandra.thrift.CounterSuperColumn
-
- CounterSuperColumn(ByteBuffer, List<CounterColumn>) - Constructor for class org.apache.cassandra.thrift.CounterSuperColumn
-
- CounterSuperColumn(CounterSuperColumn) - Constructor for class org.apache.cassandra.thrift.CounterSuperColumn
-
Performs a deep copy on other.
- CounterSuperColumn._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CounterUpdateCell - Interface in org.apache.cassandra.db
-
A counter update while it hasn't been applied yet by the leader replica.
- countLocalEndpoints(Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- countPaged(String, String, ByteBuffer, SliceQueryFilter, ConsistencyLevel, ClientState, int, long) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
- countPartitionsWithOnlyStaticData - Variable in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
- countRowsFunction - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The function used to count the number of rows of a result set.
- CQL3CasRequest - Class in org.apache.cassandra.cql3.statements
-
Processed CAS conditions and update on potentially multiple rows of the same partition.
- CQL3CasRequest(CFMetaData, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- cql3ColumnName(CFMetaData) - Method in interface org.apache.cassandra.db.composites.CellName
-
The name of the CQL3 column this cell represents.
- cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- CQL3Row - Interface in org.apache.cassandra.cql3
-
- CQL3Row.Builder - Interface in org.apache.cassandra.cql3
-
- CQL3Row.RowIterator - Interface in org.apache.cassandra.cql3
-
- CQL3RowBuilder(CFMetaData, long) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Creates a new CQL3Row builder for this type.
- CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- CQL3Type - Interface in org.apache.cassandra.cql3
-
- CQL3Type.Collection - Class in org.apache.cassandra.cql3
-
- CQL3Type.Custom - Class in org.apache.cassandra.cql3
-
- CQL3Type.Native - Enum in org.apache.cassandra.cql3
-
- CQL3Type.Raw - Class in org.apache.cassandra.cql3
-
- CQL3Type.Tuple - Class in org.apache.cassandra.cql3
-
- CQL3Type.UserDefined - Class in org.apache.cassandra.cql3
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- CqlBulkOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The CqlBulkOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
bound variable values) as CQL rows (and respective columns) in a given
table.
- CqlBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- CqlBulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop.cql3
-
- CqlBulkRecordWriter - Class in org.apache.cassandra.hadoop.cql3
-
The CqlBulkRecordWriter
maps the output <key, value>
pairs to a Cassandra column family.
- CqlBulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- CqlInputFormat - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- CqlInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- CqlMetadata - Class in org.apache.cassandra.thrift
-
- CqlMetadata() - Constructor for class org.apache.cassandra.thrift.CqlMetadata
-
- CqlMetadata(Map<ByteBuffer, String>, Map<ByteBuffer, String>, String, String) - Constructor for class org.apache.cassandra.thrift.CqlMetadata
-
- CqlMetadata(CqlMetadata) - Constructor for class org.apache.cassandra.thrift.CqlMetadata
-
Performs a deep copy on other.
- CqlMetadata._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CQLMetrics - Class in org.apache.cassandra.metrics
-
- CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
-
- CqlNativeStorage - Class in org.apache.cassandra.hadoop.pig
-
Deprecated.
- CqlNativeStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- CqlNativeStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The CqlOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
bound variable values) as CQL rows (and respective columns) in a given
table.
- CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- CqlPreparedResult - Class in org.apache.cassandra.thrift
-
- CqlPreparedResult() - Constructor for class org.apache.cassandra.thrift.CqlPreparedResult
-
- CqlPreparedResult(int, int) - Constructor for class org.apache.cassandra.thrift.CqlPreparedResult
-
- CqlPreparedResult(CqlPreparedResult) - Constructor for class org.apache.cassandra.thrift.CqlPreparedResult
-
Performs a deep copy on other.
- CqlPreparedResult._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CqlRecordReader - Class in org.apache.cassandra.hadoop.cql3
-
CqlRecordReader reads the rows return from the CQL query
It uses CQL auto-paging.
- CqlRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- CqlResult - Class in org.apache.cassandra.thrift
-
- CqlResult() - Constructor for class org.apache.cassandra.thrift.CqlResult
-
- CqlResult(CqlResultType) - Constructor for class org.apache.cassandra.thrift.CqlResult
-
- CqlResult(CqlResult) - Constructor for class org.apache.cassandra.thrift.CqlResult
-
Performs a deep copy on other.
- CqlResult._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CqlResultType - Enum in org.apache.cassandra.thrift
-
- CqlRow - Class in org.apache.cassandra.thrift
-
Row returned from a CQL query.
- CqlRow() - Constructor for class org.apache.cassandra.thrift.CqlRow
-
- CqlRow(ByteBuffer, List<Column>) - Constructor for class org.apache.cassandra.thrift.CqlRow
-
- CqlRow(CqlRow) - Constructor for class org.apache.cassandra.thrift.CqlRow
-
Performs a deep copy on other.
- CqlRow._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CQLSSTableWriter - Class in org.apache.cassandra.io.sstable
-
Utility to write SSTables.
- CQLSSTableWriter.Builder - Class in org.apache.cassandra.io.sstable
-
A Builder for a CQLSSTableWriter object.
- CQLStatement - Interface in org.apache.cassandra.cql3
-
- CRC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CRC32Factory - Class in org.apache.cassandra.utils
-
CRC Factory that uses our pure java crc for default
- CRC32Factory() - Constructor for class org.apache.cassandra.utils.CRC32Factory
-
- CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- create() - Method in interface org.apache.cassandra.cache.CacheProvider
-
- create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- create(Pair<String, String>, ByteBuffer, CellName) - Static method in class org.apache.cassandra.cache.CounterCacheKey
-
- create() - Method in class org.apache.cassandra.cache.NopCacheProvider
-
- create() - Method in class org.apache.cassandra.cache.OHCProvider
-
- create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create() - Method in class org.apache.cassandra.cache.SerializingCacheProvider
-
- create() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
This creates a new ExecutorLocals object based on what is already set.
- create(TraceState) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
- create(String, String) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- create(TupleType) - Static method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- create(UserType) - Static method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- create(FunctionName, List<AbstractType<?>>, AbstractType<?>, FunctionName, FunctionName, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- create(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
- create(ConsistencyLevel, List<ByteBuffer>, boolean, int, PagingState, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- create(ResultSet) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(List<Map<String, ByteBuffer>>) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(SelectStatement, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
-
- create(CellName, ByteBuffer, long, int, CFMetaData) - Static method in class org.apache.cassandra.db.AbstractCell
-
- create(CellName, ByteBuffer, long, long, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.BufferCounterCell
-
- create(CellName, ByteBuffer, long, int, int, int, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.BufferExpiringCell
-
- create(long, long) - Static method in class org.apache.cassandra.db.ClockAndCount
-
- create(CFMetaData, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
Returns a (initially empty) column map whose columns are sorted
according to the provided comparator.
- create(CFMetaData, boolean) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(CFMetaData) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String, String) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
- create() - Method in interface org.apache.cassandra.db.columniterator.IColumnIteratorFactory
-
- create(DataInput, ByteBuffer) - Static method in exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- create(ColumnFamilyStore, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(ColumnFamilyStore, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(Composite, ColumnDefinition, ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- create(Composite, ColumnDefinition) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Creates a new CellName given a clustering prefix and a CQL3 column.
- create(Composite, ColumnDefinition, ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Creates a new collection CellName given a clustering prefix, a CQL3 column and the collection element.
- create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- create(Composite, ColumnDefinition, ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
-
- create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- create(ColumnFamilyStore, DataRange, List<IndexExpression>, int, boolean, long) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- create(ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- create(String, ByteBuffer, String, long, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.ReadCommand
-
- create(long, DeletionTime, ColumnIndex) - Static method in class org.apache.cassandra.db.RowIndexEntry
-
- create(Function, Throwable) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- 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(Descriptor, Long, Long, CFMetaData, IPartitioner, MetadataCollector) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(Descriptor, long, long) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(Descriptor, long, long, int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(CFMetaData, Descriptor, long, long, int, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(String, long, long, int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create(String, long, long) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(Collection<SSTableWriter>) - Method in class org.apache.cassandra.streaming.StreamLockfile
-
- create(Message.Type, int, int, EnumSet<Frame.Header.Flag>, ByteBuf) - Static method in class org.apache.cassandra.transport.Frame
-
- create(C, C) - Static method in class org.apache.cassandra.utils.Interval
-
- create(C, C, D) - Static method in class org.apache.cassandra.utils.Interval
-
- create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
-
- create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>, Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- CreateAggregateStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE AGGREGATE
statement parsed from a CQL query.
- CreateAggregateStatement(FunctionName, List<CQL3Type.Raw>, String, CQL3Type.Raw, String, Term.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Creates all storage-related directories.
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
Deprecated.
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
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.
- createBroken(FunctionName, List<AbstractType<?>>, AbstractType<?>, ByteBuffer, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- createBrokenFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
-
It can happen that a function has been declared (is listed in the scheam) but cannot
be loaded (maybe only on some nodes).
- createCachedThreadpoolWithMaxSize(String) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Creates a thread pool that creates new threads as needed, but
will reuse previously constructed threads when they are
available.
- createClusteringPrefix(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- createColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- createColumnFamilyCounter(String) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Creates a counter that will also have a global counter thats the sum of all counters across
different column families
- createColumnFamilyGauge(String, Gauge<T>) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Create a gauge that will be part of a merged version of all column families.
- createColumnFamilyGauge(String, Gauge<T>, Gauge<G>) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Create a gauge that will be part of a merged version of all column families.
- createColumnFamilyHistogram(String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Create a histogram-like interface that will register both a CF, keyspace and global level
histogram and forward any updates to both
- createColumnFamilyStore(Keyspace, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, IPartitioner, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompactionStrategyInstance(Class<? extends AbstractCompactionStrategy>, ColumnFamilyStore, Map<String, String>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompactionStrategyInstance(ColumnFamilyStore) - Method in class org.apache.cassandra.config.CFMetaData
-
Deprecated.
- createCompressor(ParameterizedClass) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
-
- createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- createConnection(InetAddress) - Method in class org.apache.cassandra.streaming.DefaultConnectionFactory
-
Connect to peer and start exchanging message.
- createConnection(InetAddress) - Method in interface org.apache.cassandra.streaming.StreamConnectionFactory
-
- createConnection() - Method in class org.apache.cassandra.streaming.StreamSession
-
- createConnection(InetAddress) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
-
- createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createDescriptor(File, String, String, SSTableFormat.Type) - Static method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createFragmentIterator(SSTableReader, RandomAccessReader, DecoratedKey, long, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used only by scrubber to solve problems with data written after the END_OF_ROW marker.
- CreateFunctionStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE FUNCTION
statement parsed from a CQL query.
- CreateFunctionStatement(FunctionName, String, String, List<ColumnIdentifier>, List<CQL3Type.Raw>, CQL3Type.Raw, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- createGlobal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single global, 2.1+ shard (a result of increment).
- createHardLink(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(CFName, IndexName, IndexTarget.Raw, IndexPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- createInRelation(List<ColumnIdentifier.Raw>, List<? extends Term.MultiColumnRaw>) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column IN relation with a list of IN values or markers.
- createInRelation(ColumnIdentifier.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- createInstance(ColumnFamilyStore, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
This is the primary way to create a secondary index instance for a CF column.
- createKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- createKeyspaceFromName(String) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- 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.format.SSTableReader
-
- createLocal(CellName, long, long, long) - Static method in class org.apache.cassandra.db.BufferCounterCell
-
- createLocal(long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single local shard.
- createMessage() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- createMessage() - Method in class org.apache.cassandra.db.Mutation
-
- createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.Mutation
-
- createMessage() - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceReply
-
- createMessage() - Method in class org.apache.cassandra.db.ReadCommand
-
- createMessage() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- createMessage() - Method in class org.apache.cassandra.db.TruncateResponse
-
- createMessage() - Method in class org.apache.cassandra.db.Truncation
-
- createMessage() - Method in class org.apache.cassandra.db.WriteResponse
-
- createMessage() - Method in class org.apache.cassandra.repair.messages.RepairMessage
-
- createMessage(boolean, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
Create serialized message.
- createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- createMetricName(String) - Method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
-
Create a qualified name from given metric name.
- createNonInRelation(List<ColumnIdentifier.Raw>, Operator, Term.MultiColumnRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column EQ, LT, LTE, GT, or GTE relation.
- createNotification(String) - Static method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- createPooledReader() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- createPooledReader() - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- createReader() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- createReader() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- createReader() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
Deprecated.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- createRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single remote shard.
- createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of a CREATE ROLE statement.
- CreateRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateRoleStatement(RoleName, RoleOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Called at query time
Creates a implementation specific searcher instance for this index type
- createServerSocket(int) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
-
- createSingleMarkerInRelation(List<ColumnIdentifier.Raw>, Tuples.INRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
-
Creates a multi-column IN relation with a marker for the IN values.
- createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
-
- createSslHandler() - Method in class org.apache.cassandra.transport.Server.AbstractSecureIntializer
-
- createSSTableAndLengthPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- createSSTableAndMinTimestampPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- createTableFromName(String, String) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- createTableFromTablePartitionAndColumnsPartition(Row, Row) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- createTableFromTableRowAndColumnRows(UntypedResultSet.Row, UntypedResultSet) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- CreateTableStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE TABLE
parsed from a CQL query statement.
- CreateTableStatement(CFName, CFPropDefs, boolean, Set<ColumnIdentifier>, UUID) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- CreateTableStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- createTracingSession() - Method in class org.apache.cassandra.service.QueryState
-
- CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTriggerStatement(CFName, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- CreateTypeStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTypeStatement(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- createWithFixedPoolSize(String, int) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Returns a ThreadPoolExecutor with a fixed number of threads.
- createWithMaximumPoolSize(String, int, int, TimeUnit) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
Returns a ThreadPoolExecutor with a fixed maximum number of threads, but whose
threads are terminated when idle for too long.
- createWriter(ColumnFamilyStore, File, long, long, SSTableReader) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- createWriter(ColumnFamilyStore, long, long, SSTableFormat.Type) - Method in class org.apache.cassandra.streaming.StreamReader
-
- createWriterForAntiCompaction(ColumnFamilyStore, File, int, long, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- credentials - Variable in class org.apache.cassandra.thrift.AuthenticationRequest
-
- credentials - Variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- CredentialsMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- CredentialsMessage() - Constructor for class org.apache.cassandra.transport.messages.CredentialsMessage
-
- cross_node_timeout - Variable in class org.apache.cassandra.config.Config
-
- csZoneDc - Variable in class org.apache.cassandra.locator.CloudstackSnitch
-
- csZoneRack - Variable in class org.apache.cassandra.locator.CloudstackSnitch
-
- CType - Interface in org.apache.cassandra.db.composites
-
A type for a Composite.
- CType.Serializer - Interface in org.apache.cassandra.db.composites
-
- current() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
returns the currently visible readers managed by this transaction
- current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
return the current version of the provided reader, whether or not it is visible or staged;
i.e.
- current() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- current() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- current_values - Variable in class org.apache.cassandra.thrift.CASResult
-
- current_version - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
Increment this number if there is a changes in the commit log disc layout or MessagingVersion changes.
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.transport.Server
-
- currentBlocked - Variable in class org.apache.cassandra.metrics.SEPMetrics
-
Number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- currentBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- currentBuffer() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentLimit() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- currentlyRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentWriter() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- Cursor<K,V extends K> - Class in org.apache.cassandra.utils.btree
-
An extension of Path which provides a public interface for iterating over or counting a subrange of the tree
- Cursor() - Constructor for class org.apache.cassandra.utils.btree.Cursor
-
- Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
- customClass - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- CustomClassLoader - Class in org.apache.cassandra.triggers
-
Custom class loader will load the classes from the class path, CCL will load
the classes from the the URL first, if it cannot find the required class it
will let the parent class loader do the its job.
- CustomClassLoader(ClassLoader) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
-
- CustomClassLoader(ClassLoader, File) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
-
- CustomFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- CustomPayloadMirroringQueryHandler - Class in org.apache.cassandra.cql3
-
Custom QueryHandler that sends custom request payloads back with the result.
- CustomPayloadMirroringQueryHandler() - Constructor for class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- CustomTNonBlockingServer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer(TNonblockingServer.Args) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- CustomTNonBlockingServer.CustomFrameBuffer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
-
- CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
-
Slightly modified version of the Apache Thrift TThreadPoolServer.
- CustomTThreadPoolServer(TThreadPoolServer.Args, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- CustomTThreadPoolServer.Factory - Class in org.apache.cassandra.thrift
-
- Factory() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Factory
-
- factory - Static variable in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- factory - Static variable in class org.apache.cassandra.db.AtomicBTreeColumns
-
- Factory() - Constructor for class org.apache.cassandra.db.ColumnFamily.Factory
-
- Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
-
- Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
-
- factory - Static variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
- factory - Static variable in class org.apache.cassandra.metrics.CompactionMetrics
-
- factory - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
- factory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.Cassandra.Client.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
-
- Factory() - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer.Factory
-
- fail() - Method in class org.apache.cassandra.repair.Validator
-
Called when some error during the validation happened.
- failedRepairJob(UUID, String, String, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- failParentRepair(UUID, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- failRepairs(UUID, String, String[], Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- FAILURE_CALLBACK_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
-
- FAILURE_RESPONSE_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
-
- FailureDetector - Class in org.apache.cassandra.gms
-
This FailureDetector is an implementation of the paper titled
"The Phi Accrual Failure Detector" by Hayashibara.
- FailureDetector() - Constructor for class org.apache.cassandra.gms.FailureDetector
-
- FailureDetectorInfo - Class in org.apache.cassandra.tools.nodetool
-
- FailureDetectorInfo() - Constructor for class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
-
- FailureDetectorMBean - Interface in org.apache.cassandra.gms
-
- FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- failures - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- failures - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- FastByteArrayInputStream - Class in org.apache.cassandra.io.util
-
A specialized InputStream
for reading the contents of a byte array.
- FastByteArrayInputStream(byte[]) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
.
- FastByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
with the initial position set to offset
and the
number of bytes available set to offset
+ length
.
- FastByteOperations - Class in org.apache.cassandra.utils
-
Utility code to do optimized byte-array comparison.
- FastByteOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations
-
- FastByteOperations.ByteOperations - Interface in org.apache.cassandra.utils
-
- FastByteOperations.PureJavaOperations - Class in org.apache.cassandra.utils
-
- FastByteOperations.UnsafeOperations - Class in org.apache.cassandra.utils
-
- FBUtilities - Class in org.apache.cassandra.utils
-
- FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
-
- fetchAsync() - Method in class org.apache.cassandra.dht.RangeStreamer
-
- fetchPage(int) - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- fetchPage(int) - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Fetches the next page.
- field - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CASResult
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CfSplit
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Column
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CqlResult
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.CqlRow
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Deletion
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- fieldForId(int) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.KeyCount
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.KeyRange
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.KeySlice
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.KsDef
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.Mutation
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.SliceRange
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.TokenRange
-
- fieldForId(int) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- fieldForId(int) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- fieldName(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldNameAsString(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldNames() - Method in class org.apache.cassandra.db.marshal.UserType
-
- fields - Variable in class org.apache.cassandra.serializers.TupleSerializer
-
- fields - Variable in class org.apache.cassandra.serializers.UserTypeSerializer
-
- fieldSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.UserTypes
-
- fieldType(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldTypes() - Method in class org.apache.cassandra.db.marshal.UserType
-
- fifteenMinuteRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Returns the 15-minute rate in terms of events per second.
- file - Variable in exception org.apache.cassandra.io.util.ChecksummedRandomAccessReader.CorruptFileException
-
- file_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- FILE_EXT - Static variable in class org.apache.cassandra.streaming.StreamLockfile
-
- FileCacheMetrics - Class in org.apache.cassandra.metrics
-
- FileCacheMetrics() - Constructor for class org.apache.cassandra.metrics.FileCacheMetrics
-
- FileCacheService - Class in org.apache.cassandra.service
-
- FileCacheService() - Constructor for class org.apache.cassandra.service.FileCacheService
-
- FileCacheService.CacheKey - Class in org.apache.cassandra.service
-
- FileDataInput - Interface in org.apache.cassandra.io.util
-
- fileDigestValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- FileDigestValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
-
- FileMark - Interface in org.apache.cassandra.io.util
-
- FileMessageHeader - Class in org.apache.cassandra.streaming.messages
-
StreamingFileHeader is appended before sending actual data to describe what it's sending.
- FileMessageHeader(UUID, int, String, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionInfo, long, int) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- FileMessageHeader(UUID, int, String, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionMetadata, long, int) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fileName - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- filenameFor(String) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- filePath() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- files - Variable in class org.apache.cassandra.streaming.StreamSummary
-
Number of files to transfer.
- files - Variable in class org.apache.cassandra.streaming.StreamTransferTask
-
- fileSent(FileMessageHeader) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after sending FileMessageHeader.
- fileSeqNum - Variable in class org.apache.cassandra.streaming.StreamReader
-
- FileUtils - Class in org.apache.cassandra.io.util
-
- filter() - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
-
- filter(ColumnFamilyStore.AbstractScanIterator, ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- filter - Variable in class org.apache.cassandra.db.filter.QueryFilter
-
- filter() - Method in class org.apache.cassandra.db.ReadCommand
-
- filter - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- filter() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- filter - Variable in class org.apache.cassandra.db.SliceFromReadCommand
-
- filter() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
-
- filterCipherSuites(String[], String[]) - Static method in class org.apache.cassandra.security.SSLFactory
-
- FilterFactory - Class in org.apache.cassandra.utils
-
- FilterFactory() - Constructor for class org.apache.cassandra.utils.FilterFactory
-
- filterForQuery(Keyspace, List<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- filterForQuery(Keyspace, List<InetAddress>, ReadRepairDecision) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.CachedHashDecoratedKey
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.DecoratedKey
-
- filterHash(long[]) - Method in class org.apache.cassandra.db.PreHashedDecoratedKey
-
- filterHash(long[]) - Method in interface org.apache.cassandra.utils.IFilter.FilterKey
-
Places the murmur3 hash of the key in the given long array of size at least two.
- filterSSTablesForReads(List<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- filterSSTablesForReads(List<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Filters SSTables that are to be blacklisted from the given collection
- finalFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- finalizeLength(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- finalizeMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- finalizeMetadata(String, double, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- finalReader - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
-
- finalState - Variable in exception org.apache.cassandra.streaming.StreamException
-
- find(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- find(FunctionName, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- find(String) - Method in class org.apache.cassandra.db.Directories
-
- find(Object[], Comparator<V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CASResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Column._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CASResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Column._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CASResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Column._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByValue(int) - Static method in enum org.apache.cassandra.thrift.Compression
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.cassandra.thrift.ConsistencyLevel
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.cassandra.thrift.CqlResultType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.cassandra.thrift.IndexOperator
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.cassandra.thrift.IndexType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findNested(Throwable) - Static method in error org.apache.cassandra.io.FSError
-
Unwraps the Throwable cause chain looking for an FSError instance
- findPositionOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
-
Finds the position of a shard with the given id within the context (via binary search).
- findSupportingVersion(CassandraVersion...) - Method in class org.apache.cassandra.utils.CassandraVersion
-
Returns a version that is backward compatible with this version amongst a list
of provided version, or null if none can be found.
- finish() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
we are done, return the finished sstables so that the caller can mark the old ones as compacted
- finish - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- finish() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- finish() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
Finishes the new file(s)
Creates final files, adds the new files to the Tracker (via replaceReader).
- finish(long, boolean) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
-
- finish() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- finish - Variable in class org.apache.cassandra.thrift.ColumnSlice
-
- finish - Variable in class org.apache.cassandra.thrift.SliceRange
-
- finish() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
convenience method to both prepareToCommit() and commit() in one operation;
only of use to outer-most transactional object of an object graph
- finishAddingAtoms() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
-
- finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
-
- finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- finishCompaction(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Deletes the entry for this compaction from the set of compactions in progress.
- finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.metrics.CompactionMetrics
-
- finishCompactionsAndShutdown(long, TimeUnit) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- finished() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
remove the event complete
- finished() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Open the resultant SSTableReader once it has been fully written, and all related state
is ready to be finalised including other sstables being written involved in the same operation
- finished() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- finishLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- finishLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- finishOnClose() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- finishParentSession(UUID, Set<InetAddress>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Run final process of repair.
- finishSampling(int) - Method in class org.apache.cassandra.utils.TopKSampler
-
Call to stop collecting samples, and gather the results
- finishShadowRound(Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
- finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- finishTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- finishWriteFor(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
Block for @param alloc to be sync'd as necessary, and handle bookkeeping
- fireErrorAndComplete(String, int, int, String) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
-
- first - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- first() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- firstKeyBeyond(RowPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Finds and returns the first key beyond a given token in this SSTable or null if no such key exists.
- firstName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- firstNotCovered(Iterable<ReplayPosition.ReplayFilter>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- firstToken(ArrayList<Token>, Token) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
- firstTokenIndex(ArrayList, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
- fixedRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
-
- flag - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- flags - Variable in class org.apache.cassandra.transport.Frame.Header
-
- floatingPoint(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- FloatSerializer - Class in org.apache.cassandra.serializers
-
- FloatSerializer() - Constructor for class org.apache.cassandra.serializers.FloatSerializer
-
- FloatType - Class in org.apache.cassandra.db.marshal
-
- floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- flush() - Method in class org.apache.cassandra.db.Keyspace
-
- flush() - Method in class org.apache.cassandra.db.Memtable
-
- flush() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- flush() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
-
- flush() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- flush() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
If buffer is dirty, flush it's contents to the operating system.
- flush() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
-
- Flush - Class in org.apache.cassandra.tools.nodetool
-
- Flush() - Constructor for class org.apache.cassandra.tools.nodetool.Flush
-
- flushBeforeTransfer(boolean) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Set flushBeforeTransfer option.
- flushData() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- flushData() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- flushData() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Override this method instead of overriding flush()
- flushIndexesBlocking() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Flush all indexes to disk
- flushingMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
-
contains all memtables that are no longer referenced for writing and are queued for / in the process of being
flushed.
- flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
-
True if a cache flush is currently executing: only one may execute at a time.
- flushInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- FlushLargestColumnFamily() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.FlushLargestColumnFamily
-
- fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- folderSize(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Get the size of a directory in bytes
- force(MappedByteBuffer) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- force(FileChannel, boolean) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- forceAnnounceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
Announces the table even if the definition is already know locally.
- forceBatchlogReplay() - Method in class org.apache.cassandra.db.BatchlogManager
-
- forceBatchlogReplay() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
Forces batchlog replay.
- forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceBlockingFlush() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- forceBlockingFlush() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Forces this indexes' in memory data to disk
- forceBlockingFlush(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- forceCleanup(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceConviction(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- forceConviction(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
force conviction of endpoint in the failure detector
- forceFilterFailures() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
For testing purposes only.
- forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Flush if there is unflushed data in the memtables
- forceFlush(ReplayPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
- forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- forceKeyspaceCleanup(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCleanup(PrintStream, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCompaction(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compaction of a single keyspace
- forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Flush all memtables for a keyspace and column families.
- forceKeyspaceFlush(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Flush all memtables for the given column families, or all columnfamilies for the given keyspace
if none are explicitly listed.
- forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceMajorCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceMajorCompaction(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
force a major compaction of this column family
- forceNewerGeneration() - Method in class org.apache.cassandra.gms.Gossiper
-
- forceRecycleAllSegments(Iterable<UUID>) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
- forceRecycleAllSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
- forceRemoveCompletion() - Method in class org.apache.cassandra.service.StorageService
-
Force a remove operation to complete.
- forceRemoveCompletion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Force a remove operation to finish.
- forceRemoveCompletion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairAsync(String, RepairOption, boolean) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceShutdown() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Shutdowns both compaction and validation executors, cancels running compaction / validation,
and waits for tasks to complete if tasks were not cancelable.
- forceShutdown(Throwable) - Method in class org.apache.cassandra.repair.RepairSession
-
clear all RepairJobs and terminate this session.
- forceStaticInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- forceTerminateAllRepairSessions() - Method in class org.apache.cassandra.service.StorageService
-
- forceTerminateAllRepairSessions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- forceUserDefinedCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- forceUserDefinedCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Triggers the compaction of user specified sstables.
- forColumns(CFMetaData, List<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.Selection
-
- forExternalCalls(SocketAddress) - Static method in class org.apache.cassandra.service.ClientState
-
- forInternalCalls(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- forInternalCalls(List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.ClientState
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
-
- ForKey() - Constructor for class org.apache.cassandra.db.RowPosition.ForKey
-
- forKeyRange(Range<RowPosition>) - Static method in class org.apache.cassandra.db.DataRange
-
- format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- format - Variable in class org.apache.cassandra.io.sstable.format.Version
-
- format - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable format
- format - Variable in class org.apache.cassandra.streaming.StreamReader
-
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- formatType - Variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
- formatType - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- forProtocolVersion(int) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- forStatement(int) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- forTable(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The schema (CREATE TABLE statement) for the table for which sstable are to be created.
- forThrift(int, List<ColumnSpecification>) - Static method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- forTokenRange(Range<Token>) - Static method in class org.apache.cassandra.db.DataRange
-
- FORWARD_FROM - Static variable in class org.apache.cassandra.db.Mutation
-
- FORWARD_TO - Static variable in class org.apache.cassandra.db.Mutation
-
- forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- forwardMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
-
- Frame - Class in org.apache.cassandra.transport
-
- Frame.Compressor - Class in org.apache.cassandra.transport
-
- Frame.Decoder - Class in org.apache.cassandra.transport
-
- Frame.Decompressor - Class in org.apache.cassandra.transport
-
- Frame.Encoder - Class in org.apache.cassandra.transport
-
- Frame.Header - Class in org.apache.cassandra.transport
-
- Frame.Header.Flag - Enum in org.apache.cassandra.transport
-
- FrameCompressor - Interface in org.apache.cassandra.transport
-
- FrameCompressor.LZ4Compressor - Class in org.apache.cassandra.transport
-
- FrameCompressor.SnappyCompressor - Class in org.apache.cassandra.transport
-
- free() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- free() - Method in class org.apache.cassandra.io.util.Memory
-
- free() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- free(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- freeze() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- freeze() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- freeze() - Method in class org.apache.cassandra.db.marshal.ListType
-
- freeze() - Method in class org.apache.cassandra.db.marshal.MapType
-
- freeze() - Method in class org.apache.cassandra.db.marshal.SetType
-
- from(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- from(int) - Static method in enum org.apache.cassandra.db.composites.Composite.EOC
-
- from(String, String, String, Map.Entry<String, Pair<Long, Long>>, TabularDataSupport) - Static method in class org.apache.cassandra.db.SnapshotDetailsTabularData
-
- from - Variable in class org.apache.cassandra.net.IncomingTcpConnection
-
- from - Variable in class org.apache.cassandra.net.MessageIn
-
- from - Variable in class org.apache.cassandra.net.MessageOut
-
- from - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- fromAbstractType(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- fromByte(byte) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
- fromByte(byte) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundCType
-
- fromByteBuffer(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CType
-
Deserialize a Composite from a ByteBuffer.
- fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- fromBytes(ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
-
- fromCode(int) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
- fromColumnDefinition(ColumnDefinition) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- fromException(Throwable) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- fromException(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
-
- fromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Component
-
Filename of the form "<ksname>/<cfname>-[tmp-][<version>-]<gen>-<component>",
- fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(String, SSTableFormat.Type) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
- fromFilename(File, String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
Filename of the form is vary by version:
<ksname>-<cfname>-(tmp-)?<version>-<gen>-<component> for cassandra 2.0 and before
(<tmp marker>-)?<version>-<gen>-<component> for cassandra 3.0 and later
If this is for SSTable of secondary index, directory should ends with index name for 2.1+.
- fromHeader(File) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- fromId(int) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- fromInt(int) - Static method in class org.apache.cassandra.utils.CounterId
-
Function for test purposes, do not use otherwise.
- FromJsonFct - Class in org.apache.cassandra.cql3.functions
-
- fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Given a parsed JSON string, return a byte representation of the object.
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ListType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LongType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.MapType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SetType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.cache.CachingOptions
-
- fromName(String) - Static method in class org.apache.cassandra.auth.DataResource
-
Parses a data resource name into a DataResource instance.
- fromName(String) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Parses a resource name into a FunctionResource instance.
- fromName(String) - Static method in class org.apache.cassandra.auth.Resources
-
Creates an IResource instance from its external name.
- fromName(String) - Static method in class org.apache.cassandra.auth.RoleResource
-
Parses a role resource name into a RoleResource instance.
- fromName(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
-
Return RepairParallelism that match given name.
- fromOpcode(int, Message.Direction) - Static method in enum org.apache.cassandra.transport.Message.Type
-
- fromPreV3Batch(ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- fromProtocolV1(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- fromProtocolV2(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- fromSCFilter(CellNameType, ByteBuffer, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSCNamesFilter(CellNameType, ByteBuffer, NamesQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSCSliceFilter(CellNameType, ByteBuffer, SliceQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSelectors(CFMetaData, List<RawSelector>) - Static method in class org.apache.cassandra.cql3.selection.Selection
-
- fromSerialized(ByteBuffer, ListType, int) - Static method in class org.apache.cassandra.cql3.Lists.Value
-
- fromSerialized(ByteBuffer, MapType, int) - Static method in class org.apache.cassandra.cql3.Maps.Value
-
- fromSerialized(ByteBuffer, SetType, int) - Static method in class org.apache.cassandra.cql3.Sets.Value
-
- fromSerialized(ByteBuffer, ListType, QueryOptions) - Static method in class org.apache.cassandra.cql3.Tuples.InValue
-
- fromSerialized(ByteBuffer, TupleType) - Static method in class org.apache.cassandra.cql3.Tuples.Value
-
- fromSerializedValue(byte) - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
- fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions
-
- fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions.KeyCache
-
- fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions.RowCache
-
- fromString(String) - Static method in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a byte representation of the given string.
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ByteType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.LongType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ShortType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- fromThrift(String, String) - Static method in class org.apache.cassandra.cache.CachingOptions
-
- fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(String, String, AbstractType<?>, AbstractType<?>, ColumnDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThriftCqlRow(CqlRow, CqlResult) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
Create CFMetaData from thrift
CqlRow
that contains columns from schema_columnfamilies.
- fromThriftForUpdate(CfDef, CFMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- fromType(AbstractType, int) - Static method in enum org.apache.cassandra.transport.DataType
-
- fromValue(int) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
- frozen - Variable in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- frozen(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- FrozenType - Class in org.apache.cassandra.db.marshal
-
A fake type that is only used for parsing type strings that include frozen types.
- FrozenType() - Constructor for class org.apache.cassandra.db.marshal.FrozenType
-
- FSError - Error in org.apache.cassandra.io
-
- FSError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
-
- FSErrorHandler - Interface in org.apache.cassandra.io
-
Interface for handling file system errors.
- FSReadError - Error in org.apache.cassandra.io
-
- FSReadError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSReadError
-
- FSReadError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSReadError
-
- FSWriteError - Error in org.apache.cassandra.io
-
- FSWriteError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSWriteError
-
- FSWriteError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSWriteError
-
- fullCollection(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
-
- fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
-
The top level range that this MerkleTree covers.
- fullSize - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- fullType - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- function(String, String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Creates a FunctionResource representing a specific, keyspace-scoped function.
- Function - Interface in org.apache.cassandra.cql3.functions
-
- FunctionCall - Class in org.apache.cassandra.cql3.functions
-
- FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
-
- FunctionExecutionException - Exception in org.apache.cassandra.exceptions
-
- FunctionExecutionException(FunctionName, List<String>, String) - Constructor for exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- functionFromCql(String, String, List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Creates a FunctionResource representing a specific, keyspace-scoped function.
- FunctionName - Class in org.apache.cassandra.cql3.functions
-
- FunctionName(String, String) - Constructor for class org.apache.cassandra.cql3.functions.FunctionName
-
- functionName - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
-
- functionName - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
-
- FunctionResource - Class in org.apache.cassandra.auth
-
IResource implementation representing functions.
- Functions - Class in org.apache.cassandra.cql3.functions
-
- FUNCTIONS - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
-
- functionSignatureWithNameAndTypes(AbstractFunction) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- functionSignatureWithTypes(AbstractFunction) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- gatherTombstones(ColumnFamily, Iterator<? extends OnDiskAtom>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
Given an iterator of on disk atom, returns an iterator that filters the tombstone range
markers adding them to returnCF
and returns the normal column.
- GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- gc_grace_seconds - Variable in class org.apache.cassandra.thrift.CfDef
-
- gc_log_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
-
- gc_warn_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
-
- gcBefore(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- gcBefore - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- gcBefore - Variable in class org.apache.cassandra.repair.Validator
-
- gceRegion - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- gceZone - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- GCInspector - Class in org.apache.cassandra.service
-
- GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
-
- GCInspectorMXBean - Interface in org.apache.cassandra.service
-
- GcStats - Class in org.apache.cassandra.tools.nodetool
-
- GcStats() - Constructor for class org.apache.cassandra.tools.nodetool.GcStats
-
- gcUpdaterFor(DecoratedKey) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Updated closure with only the modified row key.
- GE - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
-
- generate() - Static method in class org.apache.cassandra.utils.CounterId
-
- generateLegacyCfId(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
Generates deterministic UUID from keyspace/columnfamily name pair.
- generation - Static variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- generations - Variable in class org.apache.cassandra.db.compaction.LeveledManifest
-
- get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- get(K) - Method in interface org.apache.cassandra.cache.ICache
-
- get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- get(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- get() - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
-
This is called when scheduling the task, and also before calling ExecutorLocal#set(T)
when running on a
executor thread.
- get(int) - Method in class org.apache.cassandra.cql3.Constants.Value
-
- get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- get(int) - Method in class org.apache.cassandra.cql3.Lists.Value
-
- get(int) - Method in class org.apache.cassandra.cql3.Maps.Value
-
- get(int) - Method in class org.apache.cassandra.cql3.Sets.Value
-
- get(int) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- get(int) - Method in class org.apache.cassandra.cql3.Tuples.InValue
-
- get(int) - Method in class org.apache.cassandra.cql3.Tuples.Value
-
- get(int) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- get(int) - Method in class org.apache.cassandra.db.composites.BoundedComposite
-
- get(int) - Method in interface org.apache.cassandra.db.composites.Composite
-
- get(int) - Method in class org.apache.cassandra.db.composites.CompoundComposite
-
- get(int) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- get(int) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
-
- get(int) - Method in class org.apache.cassandra.db.composites.SimpleComposite
-
- get(int) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- get(boolean, boolean) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
-
- get(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- get(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.RowPosition.ForKey
-
- get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxIntTracker
-
- get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxLongTracker
-
- get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MinLongTracker
-
- get(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
Get a snitch property value or return defaultValue if not defined.
- get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
-
- get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- get() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
wait for an answer.
- get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- get() - Method in class org.apache.cassandra.service.ClientWarn
-
- get(FileCacheService.CacheKey) - Method in class org.apache.cassandra.service.FileCacheService
-
- get() - Method in class org.apache.cassandra.service.ReadCallback
-
- get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- get(byte) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Get the Column or SuperColumn at the given column_path.
- get() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get
-
- 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(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- get() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- get(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- get(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- get(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.
- get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- get_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
- get_args(ByteBuffer, ColumnPath, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
- get_args(Cassandra.get_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
Performs a deep copy on other.
- get_call(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
returns the number of columns matching predicate
for a particular key
,
ColumnFamily
and optionally SuperColumn
.
- get_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_count
-
- get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_count_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- get_count_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- get_count_args(Cassandra.get_count_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Performs a deep copy on other.
- get_count_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
-
- get_count_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- get_count_result(int, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- get_count_result(Cassandra.get_count_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Performs a deep copy on other.
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_indexed_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
- get_indexed_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_indexed_slices
-
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_indexed_slices_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- get_indexed_slices_args(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- get_indexed_slices_args(Cassandra.get_indexed_slices_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Performs a deep copy on other.
- get_indexed_slices_call(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_indexed_slices_call
-
- get_indexed_slices_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- get_indexed_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- get_indexed_slices_result(Cassandra.get_indexed_slices_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Performs a deep copy on other.
- get_multi_slice(MultiSliceRequest, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_multi_slice(MultiSliceRequest, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_multi_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_multi_slice
-
- get_multi_slice(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_multi_slice(MultiSliceRequest) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Select multiple slices of a key in a single RPC operation
- get_multi_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_multi_slice
-
- get_multi_slice(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_multi_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- get_multi_slice_args(MultiSliceRequest) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- get_multi_slice_args(Cassandra.get_multi_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
Performs a deep copy on other.
- get_multi_slice_call(MultiSliceRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_multi_slice_call
-
- get_multi_slice_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- get_multi_slice_result(List<ColumnOrSuperColumn>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- get_multi_slice_result(Cassandra.get_multi_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Performs a deep copy on other.
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_paged_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
returns a range of columns, wrapping to the next rows if necessary to collect max_results.
- get_paged_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_paged_slice
-
- get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_paged_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- get_paged_slice_args(String, KeyRange, ByteBuffer, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- get_paged_slice_args(Cassandra.get_paged_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Performs a deep copy on other.
- get_paged_slice_call(String, KeyRange, ByteBuffer, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_paged_slice_call
-
- get_paged_slice_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- get_paged_slice_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- get_paged_slice_result(Cassandra.get_paged_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Performs a deep copy on other.
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_range_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
returns a subset of columns for a contiguous range of keys.
- get_range_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_range_slices
-
- get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_range_slices_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- get_range_slices_args(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- get_range_slices_args(Cassandra.get_range_slices_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Performs a deep copy on other.
- get_range_slices_call(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_range_slices_call
-
- get_range_slices_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- get_range_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- get_range_slices_result(Cassandra.get_range_slices_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Performs a deep copy on other.
- get_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
- get_result(ColumnOrSuperColumn, InvalidRequestException, NotFoundException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
- get_result(Cassandra.get_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
Performs a deep copy on other.
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- get_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Get the group of columns contained by column_parent (either a ColumnFamily name or a ColumnFamily/SuperColumn name
pair) specified by the given SlicePredicate.
- get_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_slice
-
- get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- get_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- get_slice_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- get_slice_args(Cassandra.get_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Performs a deep copy on other.
- get_slice_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
-
- get_slice_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- get_slice_result(List<ColumnOrSuperColumn>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- get_slice_result(Cassandra.get_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Performs a deep copy on other.
- getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- getAcknowledged_by() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
if a write operation was acknowledged by some replicas but not by enough to
satisfy the required ConsistencyLevel, the number of successful
replies will be given here.
- getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getActiveContentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveContentSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getActiveOnDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveOnDiskSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveRepairedSSTableRefsForAntiCompaction(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Get the still active sstables we should run anticompaction on
note that validation and streaming do not call this method - they have to work on the actual active sstables on the node, we only call this
to know which sstables are still there that were there when we started the repair
- getActiveSegmentCompressionRatios() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveSegmentCompressionRatios() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
- getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a milliseconds-since-epoch value for a type-1 UUID.
- getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAllDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
-
- getAllDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the list of all data file locations from conf
- getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAllMemtables() - Method in class org.apache.cassandra.db.lifecycle.View
-
- getAllocator() - Method in class org.apache.cassandra.db.Memtable
-
- getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
-
Get all ranges that span the ring given a set
of tokens.
- getAllRoles() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getAllRoles() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during the execution of an unqualified LIST ROLES query.
- getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getAllSSTables() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getAllSSTables() - Method in class org.apache.cassandra.db.Keyspace
-
- getAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getAllTypes() - Method in class org.apache.cassandra.config.UTMetaData
-
- getAncestors() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds type information from @param bb to @param sb.
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getAndReferenceOverlappingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
like getOverlappingSSTables, but acquires references before returning
- getAndResetGCStats() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getAndResetStats() - Method in class org.apache.cassandra.service.GCInspector
-
- getAndResetStats() - Method in interface org.apache.cassandra.service.GCInspectorMXBean
-
- getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
-
- getApproximateKeyCount(Collection<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Calculate approximate key count.
- getArchiveCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchiveCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Command to execute to archive a commitlog segment.
- getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
You should almost never use this.
- getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.Factory
-
- getAuth_request() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- getAuthenticatedUser() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
-
Following a sucessful negotiation, get the AuthenticatedUser representing the logged in subject.
- getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthnx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthzx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAvailableRanges(String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getAvailableRanges(String, IPartitioner) - Method in class org.apache.cassandra.dht.StreamStateStore
-
- getAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- getAverageIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getAverageIndexInterval() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getBackgroundCompactionTaskSubmitter() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getBackingFiles() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
-
- getBackupsDirectory(File) - Static method in class org.apache.cassandra.db.Directories
-
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getBatchlogMutationFor(Collection<Mutation>, UUID, int) - Static method in class org.apache.cassandra.db.BatchlogManager
-
- getBatchlogReplayThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchlogTimeout() - Method in class org.apache.cassandra.db.BatchlogManager
-
- getBatchSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchSizeFailThresholdInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBatchSizeFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getBatchSizeFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for rejecting queries due to a large batch size
- getBatchSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
-
- getBlob(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- getBloom_filter_fp_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
- getBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getBloomFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the amount of memory in bytes used off heap by the bloom filter.
- getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getBootstrapTokens(TokenMetadata) - Static method in class org.apache.cassandra.dht.BootStrapper
-
if initialtoken was specified, use that (split on comma).
- getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getBoundTerms() - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Returns the number of bound terms in this statement.
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- getBoundVariables() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- getBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBroadcastAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getBroadcastRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBroadcastRpcAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getBuckets(Collection<Pair<T, Long>>, double, double, long) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getBuckets(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getBuilder(Config.DiskAccessMode, boolean) - 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(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getByte(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getByte(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getByteBuffer(long, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getByteBuffer(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getByteOrderAsymmetricColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- getByteOrderAsymmetricColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- getByteOrderColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- getByteOrderColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
- getBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- getCacheCrcPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCacheDataPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCachedCounter(ByteBuffer, CellName) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCachedPosition(KeyCacheKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCacheKey(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCacheMetric(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)
- getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCaching() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCaching() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCachingOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getCanonicalPath(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCanonicalPath(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getCasContentionTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCassandraServer() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getCellIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- getCellIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
-
- getCells_per_row_to_cache() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCF(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- getCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- getCf_defs() - Method in class org.apache.cassandra.thrift.KsDef
-
- getCf_defsIterator() - Method in class org.apache.cassandra.thrift.KsDef
-
- getCf_defsSize() - Method in class org.apache.cassandra.thrift.KsDef
-
- getCfDef(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
return the CfInfo for the column family
- getCfDef(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get the columnfamily definition for the signature
- getCFDirectories() - Method in class org.apache.cassandra.db.Directories
-
- getCfInfo(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
get the columnfamily definition for the signature
- getCfInfo(Session) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
return the CfInfo for the column family
- getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
-
Given a keyspace name and column family name, get the column family
meta data.
- getCFMetaData(UUID) - Method in class org.apache.cassandra.config.Schema
-
Get ColumnFamily metadata by its identifier
- getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
-
- getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCFMetaData(String, String, Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get CFMetaData of a column family
- getCFMetaData() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
- getCfName() - Method in class org.apache.cassandra.cql3.IndexName
-
- getCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- getCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- getCfname() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getChannel() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- 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
-
- getClient(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.Client.Factory
-
- getClientAddress() - Method in class org.apache.cassandra.service.QueryState
-
- getClientEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClientFromInputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientFromOutputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientState() - Method in class org.apache.cassandra.service.QueryState
-
- getClientTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getClockAndCountOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the clock and the count associated with the given counter id, or (0, 0) if no such shard is present.
- getClosingString() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Bounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Range
-
- getCluster(String[], Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getClusteringColumn(int) - Method in interface org.apache.cassandra.cql3.CQL3Row
-
- getClusteringColumnsAsComposites(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the requested clustering columns as Composite
s.
- getClusteringColumnsBounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the bounds (start or end) of the clustering columns.
- getClusteringColumnsBoundsAsComposites(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the bounds (start or end) of the clustering columns as Composites
.
- getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClusterName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the name of the cluster
- getClusterName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the name of the cluster
- getClusterName() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCmd(String) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getCollectionElementValue() - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getColumn(ColumnIdentifier) - Method in interface org.apache.cassandra.cql3.CQL3Row
-
- getColumn(CellName) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumn(CellName) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getColumn(CellName) - Method in class org.apache.cassandra.db.ColumnFamily
-
Get a column given its name, returning null if the column is not
present.
- getColumn() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- getColumn() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- getColumn() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- getColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
-
- getColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- getColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- getColumn_family() - Method in class org.apache.cassandra.thrift.ColumnParent
-
- getColumn_family() - Method in class org.apache.cassandra.thrift.ColumnPath
-
- getColumn_metadata() - Method in class org.apache.cassandra.thrift.CfDef
-
- getColumn_metadataIterator() - Method in class org.apache.cassandra.thrift.CfDef
-
- getColumn_metadataSize() - Method in class org.apache.cassandra.thrift.CfDef
-
- getColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- getColumn_names() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getColumn_namesIterator() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getColumn_namesSize() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getColumn_or_supercolumn() - Method in class org.apache.cassandra.thrift.Mutation
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getColumn_parent() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- getColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- getColumn_predicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getColumn_slices() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getColumn_slicesIterator() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getColumn_slicesSize() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getColumn_type() - Method in class org.apache.cassandra.thrift.CfDef
-
- getColumnComparator(CellNameType) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getColumnComparator(CellNameType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnComparator(CellNameType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnCount() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the number of columns in this map.
- getColumnDefinition(ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns the ColumnDefinition for name
.
- getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinition(CellName) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns a ColumnDefinition given a cell name.
- getColumnDefinitionComparator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionForIndex(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- getColumnDefs() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns the column definitions in position order.
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getColumnDefs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilies() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.Mutation
-
- getColumnFamilies() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
-
- getColumnFamily(DecoratedKey, Composite, Composite, boolean, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
get a list of columns starting from a given column, in a specified order.
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
-
- getColumnFamily(UUID) - Method in class org.apache.cassandra.db.Mutation
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Deprecated.
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.Mutation
-
- getColumnFamilyMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve ColumnFamily metrics
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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
-
- getColumnFamilyStoreIncludingIndexes(Pair<String, String>) - Method in class org.apache.cassandra.config.Schema
-
Retrieve a CFS by name even if that CFS is an index
An index is identified by looking for '.' in the CF name and separating to find the base table
containing the index
- getColumnFamilyStoreInstance(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
-
Returns the index of the specified column
- getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getColumnIterator(ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given columnFamily
matching the Filter criteria in sorted order.
- getColumnIterator(DecoratedKey, ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getColumnIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnMapping() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getColumnMeta(Cassandra.Client, boolean, boolean) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get column meta data
- getColumnMetadata() - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get a list of column for the column family
- getColumnName() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Returns the name of the column corresponding to the output value of the selector instances created by
this factory.
- getColumnNames() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterable with the names of columns in this column map in the same order
as the underlying columns themselves.
- getColumnNamesAsString() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
Returns the column names as a comma separated String
.
- getColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getColumns() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- getColumns() - Method in class org.apache.cassandra.thrift.CqlRow
-
- getColumns() - Method in class org.apache.cassandra.thrift.KeySlice
-
- getColumns() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- getColumnsInCommons(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
Returns the names of the columns that are specified within this Restrictions
and the other one
as a comma separated String
.
- getColumnsIterator() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- getColumnsIterator() - Method in class org.apache.cassandra.thrift.CqlRow
-
- getColumnsIterator() - Method in class org.apache.cassandra.thrift.KeySlice
-
- getColumnsIterator() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- getColumnSpecification(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Returns the column specification corresponding to the output value of the selector instances created by
this factory.
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Returns the column specifications for the bound variables (optional operation).
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- getColumnSpecifications() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
-
- getColumnsSize() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- getColumnsSize() - Method in class org.apache.cassandra.thrift.CqlRow
-
- getColumnsSize() - Method in class org.apache.cassandra.thrift.KeySlice
-
- getColumnsSize() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- getColumnsString(CellNameType, Iterable<Cell>) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getComment() - Method in class org.apache.cassandra.config.CFMetaData
-
- getComment() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCommit_consistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getCommitFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the commit log
- getCommitLogLowerBound() - Method in class org.apache.cassandra.db.Memtable
-
- getCommitLogMaxCompressionBuffersInPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getCompactedRowWriter(CompactionController, ImmutableList<OnDiskAtomIterator>) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getCompactedRowWriter(CompactionController, ImmutableList<OnDiskAtomIterator>) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getCompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getCompaction_strategy() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCompaction_strategy_options() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCompaction_strategy_optionsSize() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- getCompactionHistory() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactionHistory() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
compaction history
- getCompactionHistory() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getCompactionHistory() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionInfo() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- getCompactionInfo() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
-
- getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- getCompactionLargePartitionWarningThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getCompactionOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getCompactionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getCompactionParametersJson() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionParametersJson() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactions() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction objects.
- getCompactions() - Static method in class org.apache.cassandra.metrics.CompactionMetrics
-
- getCompactionStrategy() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getCompactionStrategy() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionStrategyClass() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompactionStrategyClass() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getCompactionSummary() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactionSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction summary strings.
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- GetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
-
- GetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
-
- getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
-
- getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds DynamicCompositeType type information from @param bb1 to @param bb2.
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator(CType, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- getComparator_type() - Method in class org.apache.cassandra.thrift.CfDef
-
- 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 class org.apache.cassandra.concurrent.SEPExecutor
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- getComponentComparator(Integer, ColumnDefinition.Kind) - 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(CompressedSequentialWriter) - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getCompression() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- getCompression() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- getCompression() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- getCompression() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- getCompression_options() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCompression_optionsSize() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the compression metadata for this sstable.
- getCompressionMetadataOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the amount of memory in bytes used off heap by the compression meta-data.
- getCompressionOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getCompressionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the compression parameters
- getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCompressor() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor used to compress the segments.
- getCompressor() - Method in class org.apache.cassandra.transport.Connection
-
- getCompressorClass() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor class.
- getCompressorName() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Returns the compressor name.
- getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentCounterWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConfiguration(JobContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke getConfiguration() on JobContext.
- getConnectedClients() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- getConnectedClients() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- getConnection(InetAddress, MessageOut) - Method in class org.apache.cassandra.net.MessagingService
-
- getConnectionFactory() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Provides connection factory.
- getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getConsistency() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- getConsistency() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- getConsistency_level() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getContactedReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
Get the replicas involved in the [finished] request.
- getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getCoreCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of compaction thread pool
- getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Returns core pool size of thread pool.
- getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of validation thread pool
- getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxCounterMBean
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getCount() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getCount() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getCount() - Method in class org.apache.cassandra.thrift.KeyCount
-
- getCount() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getCount() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getCount() - Method in class org.apache.cassandra.thrift.SliceRange
-
- getCounter(TaskInputOutputContext, String, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke getCounter() on TaskInputOutputContext.
- getCounter(Enum<?>) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getCounter(String, String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getCounter_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- getCounter_super_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- getCounterCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getCounterCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getCounterCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getCounterCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getCounterCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCounterWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCounterWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCounterWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
-
- getCrc() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- getCredentialsSize() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- getCurrent() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
- getCurrent_values() - Method in class org.apache.cassandra.thrift.CASResult
-
- getCurrent_valuesIterator() - Method in class org.apache.cassandra.thrift.CASResult
-
- getCurrent_valuesSize() - Method in class org.apache.cassandra.thrift.CASResult
-
- getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
- getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Deprecated.
- 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
-
Deprecated.
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCurrentMemtable() - Method in class org.apache.cassandra.db.lifecycle.View
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getCurrentPosition() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getCurrentStat() - Method in class org.apache.cassandra.repair.SyncTask
-
- getCurrentState() - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- getCurrentStreams() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getCurrentStreams() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
Returns the current state of all ongoing streams.
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCustomOptions(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getCustomOptions(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Where an implementation supports OPTIONS in CREATE and ALTER operations
this method should return the Map representing the custom
options associated with the role, as supplied to CREATE or ALTER.
- getCustomOptions() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a Map representing custom options
It is the responsiblity of IRoleManager implementations which support
IRoleManager.Option.OPTION to handle type checking and conversion of these
values, if present
- getCustomPayload() - Method in class org.apache.cassandra.transport.Message
-
- getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- getData() - Method in 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() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Gets the stored data center for the local node, or null if none have been set yet.
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.CloudstackSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used for this node
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String representing the datacenter this endpoint belongs to
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getDatacenter() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getDataCenters() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getDclocal_read_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
- getDcLocalReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefault_name_type() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getDefault_time_to_live() - Method in class org.apache.cassandra.thrift.CfDef
-
- getDefault_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
-
- getDefault_value_type() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getDefaultGcBefore(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getDefaultIndexName(String, ColumnIdentifier) - Static method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
construct a map to store the mashaller type to cassandra data type mapping
- getDefaultTimeToLive() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultTimeToLive() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDeleteSourceOnSuccess(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getDeletion() - Method in class org.apache.cassandra.thrift.Mutation
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
The directories we can write to
- getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
-
- getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getDisableSTCSInL0() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDouble(String, double) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getDownEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getDownEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getDrainProgress() - Method in class org.apache.cassandra.service.StorageService
-
- getDrainProgress() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the progress of a drain operation
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- 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
-
- getDurationUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getEffectiveIndexIntervalAfterIndex(int, int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Calculates the effective index interval after the entry at `index` in an IndexSummary.
- getEffectiveIndexIntervalAfterIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns the number of primary (on-disk) index entries between the index summary entry at `index` and the next
index summary entry (assuming there is one).
- getElement(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
-
Returns the element at the given index in a list.
- getElementCount(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- getElementCount(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- getElementCount(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- getElementCount(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- getElementIndex() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getElements() - Method in class org.apache.cassandra.cql3.Lists.Value
-
- getElements() - Method in class org.apache.cassandra.cql3.Term.MultiItemTerminal
-
- getElements() - Method in class org.apache.cassandra.cql3.Tuples.Value
-
- getElementsType() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getElementsType() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.add
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.atomic_batch_mutate
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.batch_mutate
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_cluster_name
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspaces
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_local_ring
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_partitioner
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_ring
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_schema_versions
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_snitch
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits_ex
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_token_map
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_version
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_multi_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.login
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_count
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.trace_next_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.truncate
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.add
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.atomic_batch_mutate
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.batch_mutate
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.cas
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_cluster_name
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspaces
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_local_ring
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_partitioner
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_ring
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_schema_versions
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_snitch
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits_ex
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_token_map
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_version
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_count
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_indexed_slices
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_multi_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_paged_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_range_slices
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.insert
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.login
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_count
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_slice
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql3_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove_counter
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_cql_version
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_column_family
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_keyspace
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.trace_next_query
-
- getEmptyArgsInstance() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.truncate
-
- getEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- getEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- getEnd_token() - Method in class org.apache.cassandra.thrift.CfSplit
-
- getEnd_token() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getEnd_token() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getEndpoint(Range<Token>) - Method in class org.apache.cassandra.client.RingCache
-
ListMultimap promises to return a List for get(K)
- getEndpoint(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getEndpoint_details() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpoint_detailsIterator() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpoint_detailsSize() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointDowntime(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getEndpointForHostId(UUID) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the end-point for a unique host ID
- getEndpointInfo(InetAddress) - Static method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Get the raw information about an end point
- getEndpoints() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpoints(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetEndpoints - Class in org.apache.cassandra.tools.nodetool
-
- GetEndpoints() - Constructor for class org.apache.cassandra.tools.nodetool.GetEndpoints
-
- getEndpointsIterator() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getEndpointsSize() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getEndpointState(String) - Method in class org.apache.cassandra.gms.FailureDetector
-
- getEndpointState(String) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getEndpointStateForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointStates() - Method in class org.apache.cassandra.gms.Gossiper
-
- getEndpointToHostId() - Method in class org.apache.cassandra.service.StorageService
-
- getEndpointToHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of endpoint to host ID
- getEndpointToHostIdMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpointToRangesMap() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getEndpointToTokenMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getEntities() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- getEntity() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getEntryIterator(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.Memtable
-
- getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getEstimatedKeyCount() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns an estimate of the total number of keys in the SSTable.
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getExpected() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Calculate expected file size of SSTable after compaction.
- getExpectedIterator() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getExpectedSize() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- 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
-
- getExpressions() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getExpressionsIterator() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getExpressionsSize() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getExtraFilter(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
Returns a filter to query the columns from the clause that the initial slice filter may not have caught.
- getExtraFilter(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- getFactory() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getFactory() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the factory used for this ISortedColumns implementation.
- getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- getFailureDetectorPhilValues() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getfd(FileChannel) - Static method in class org.apache.cassandra.utils.CLibrary
-
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
-
Get system file descriptor from FileDescriptor object.
- getfd(String) - Static method in class org.apache.cassandra.utils.CLibrary
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CASResult._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CfDef._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Column._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Deletion._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
- getFieldName() - Method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.KsDef._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.Mutation._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
- getFieldName() - Method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
- getFieldValue(AuthenticationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- getFieldValue(AuthenticationRequest._Fields) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- getFieldValue(AuthorizationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- getFieldValue(CASResult._Fields) - Method in class org.apache.cassandra.thrift.CASResult
-
- getFieldValue(Cassandra.add_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- getFieldValue(Cassandra.add_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- getFieldValue(Cassandra.atomic_batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- getFieldValue(Cassandra.atomic_batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- getFieldValue(Cassandra.batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- getFieldValue(Cassandra.batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- getFieldValue(Cassandra.cas_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getFieldValue(Cassandra.cas_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- getFieldValue(Cassandra.describe_cluster_name_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- getFieldValue(Cassandra.describe_cluster_name_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- getFieldValue(Cassandra.describe_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- getFieldValue(Cassandra.describe_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- getFieldValue(Cassandra.describe_keyspaces_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- getFieldValue(Cassandra.describe_keyspaces_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- getFieldValue(Cassandra.describe_local_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- getFieldValue(Cassandra.describe_local_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- getFieldValue(Cassandra.describe_partitioner_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- getFieldValue(Cassandra.describe_partitioner_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- getFieldValue(Cassandra.describe_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- getFieldValue(Cassandra.describe_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- getFieldValue(Cassandra.describe_schema_versions_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- getFieldValue(Cassandra.describe_schema_versions_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- getFieldValue(Cassandra.describe_snitch_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- getFieldValue(Cassandra.describe_snitch_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- getFieldValue(Cassandra.describe_splits_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- getFieldValue(Cassandra.describe_splits_ex_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- getFieldValue(Cassandra.describe_splits_ex_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- getFieldValue(Cassandra.describe_splits_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- getFieldValue(Cassandra.describe_token_map_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- getFieldValue(Cassandra.describe_token_map_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- getFieldValue(Cassandra.describe_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- getFieldValue(Cassandra.describe_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- getFieldValue(Cassandra.execute_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- getFieldValue(Cassandra.execute_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getFieldValue(Cassandra.execute_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- getFieldValue(Cassandra.execute_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getFieldValue(Cassandra.execute_prepared_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getFieldValue(Cassandra.execute_prepared_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getFieldValue(Cassandra.execute_prepared_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- getFieldValue(Cassandra.execute_prepared_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getFieldValue(Cassandra.get_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- getFieldValue(Cassandra.get_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- getFieldValue(Cassandra.get_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- getFieldValue(Cassandra.get_indexed_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getFieldValue(Cassandra.get_indexed_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getFieldValue(Cassandra.get_multi_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- getFieldValue(Cassandra.get_multi_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getFieldValue(Cassandra.get_paged_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- getFieldValue(Cassandra.get_paged_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getFieldValue(Cassandra.get_range_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- getFieldValue(Cassandra.get_range_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getFieldValue(Cassandra.get_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getFieldValue(Cassandra.get_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- getFieldValue(Cassandra.get_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getFieldValue(Cassandra.insert_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- getFieldValue(Cassandra.insert_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- getFieldValue(Cassandra.login_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- getFieldValue(Cassandra.login_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- getFieldValue(Cassandra.multiget_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getFieldValue(Cassandra.multiget_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getFieldValue(Cassandra.multiget_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getFieldValue(Cassandra.multiget_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getFieldValue(Cassandra.prepare_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- getFieldValue(Cassandra.prepare_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- getFieldValue(Cassandra.prepare_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- getFieldValue(Cassandra.prepare_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- getFieldValue(Cassandra.remove_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- getFieldValue(Cassandra.remove_counter_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- getFieldValue(Cassandra.remove_counter_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- getFieldValue(Cassandra.remove_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- getFieldValue(Cassandra.set_cql_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- getFieldValue(Cassandra.set_cql_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- getFieldValue(Cassandra.set_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- getFieldValue(Cassandra.set_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- getFieldValue(Cassandra.system_add_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- getFieldValue(Cassandra.system_add_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- getFieldValue(Cassandra.system_add_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- getFieldValue(Cassandra.system_add_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- getFieldValue(Cassandra.system_drop_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- getFieldValue(Cassandra.system_drop_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- getFieldValue(Cassandra.system_drop_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- getFieldValue(Cassandra.system_drop_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- getFieldValue(Cassandra.system_update_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- getFieldValue(Cassandra.system_update_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- getFieldValue(Cassandra.system_update_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- getFieldValue(Cassandra.system_update_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- getFieldValue(Cassandra.trace_next_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- getFieldValue(Cassandra.trace_next_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- getFieldValue(Cassandra.truncate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- getFieldValue(Cassandra.truncate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- getFieldValue(CfDef._Fields) - Method in class org.apache.cassandra.thrift.CfDef
-
- getFieldValue(CfSplit._Fields) - Method in class org.apache.cassandra.thrift.CfSplit
-
- getFieldValue(Column._Fields) - Method in class org.apache.cassandra.thrift.Column
-
- getFieldValue(ColumnDef._Fields) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getFieldValue(ColumnOrSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- getFieldValue(ColumnParent._Fields) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- getFieldValue(ColumnPath._Fields) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- getFieldValue(ColumnSlice._Fields) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- getFieldValue(CounterColumn._Fields) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- getFieldValue(CounterSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- getFieldValue(CqlMetadata._Fields) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getFieldValue(CqlPreparedResult._Fields) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getFieldValue(CqlResult._Fields) - Method in class org.apache.cassandra.thrift.CqlResult
-
- getFieldValue(CqlRow._Fields) - Method in class org.apache.cassandra.thrift.CqlRow
-
- getFieldValue(Deletion._Fields) - Method in class org.apache.cassandra.thrift.Deletion
-
- getFieldValue(EndpointDetails._Fields) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getFieldValue(IndexClause._Fields) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getFieldValue(IndexExpression._Fields) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- getFieldValue(InvalidRequestException._Fields) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- getFieldValue(KeyCount._Fields) - Method in class org.apache.cassandra.thrift.KeyCount
-
- getFieldValue(KeyRange._Fields) - Method in class org.apache.cassandra.thrift.KeyRange
-
- getFieldValue(KeySlice._Fields) - Method in class org.apache.cassandra.thrift.KeySlice
-
- getFieldValue(KsDef._Fields) - Method in class org.apache.cassandra.thrift.KsDef
-
- getFieldValue(MultiSliceRequest._Fields) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getFieldValue(Mutation._Fields) - Method in class org.apache.cassandra.thrift.Mutation
-
- getFieldValue(NotFoundException._Fields) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- getFieldValue(SchemaDisagreementException._Fields) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- getFieldValue(SlicePredicate._Fields) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getFieldValue(SliceRange._Fields) - Method in class org.apache.cassandra.thrift.SliceRange
-
- getFieldValue(SuperColumn._Fields) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- getFieldValue(TimedOutException._Fields) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- getFieldValue(TokenRange._Fields) - Method in class org.apache.cassandra.thrift.TokenRange
-
- getFieldValue(TriggerDef._Fields) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getFieldValue(UnavailableException._Fields) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- getFifteenMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getFileDescriptor() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getFileStore(Path) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the FileStore
representing the file store where a file
is located.
- getFilter(long, int, boolean) - 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.thrift.ColumnSlice
-
- getFinish() - Method in class org.apache.cassandra.thrift.SliceRange
-
- getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- getFirstColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns the definition of the first column.
- getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getFirstEmptyKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFiveMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFormat() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- getFormatType(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getFreeSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the number of unallocated bytes on the specified partition.
- getFullyExpiredSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
Finds expired sstables
works something like this;
1.
- getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get the full class name
- getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
get the full class name
- getFunctionName() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getFunctions() - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Attributes
-
- getFunctions() - Method in class org.apache.cassandra.cql3.ColumnCondition
-
- getFunctions() - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Return an Iterable over all of the functions (both native and user-defined) used by any component
of the statement
- getFunctions() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- getFunctions() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- getFunctions() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- getFunctions() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Operation
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- getFunctions() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Return an Iterable over all of the functions (both native and user-defined) used by any component
of the restriction
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
-
- getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
-
- getFunctions() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getFunctions() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- getFunctions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getFunctions() - Method in interface org.apache.cassandra.cql3.Term
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- getFunctions(Iterable<Term>) - Static method in class org.apache.cassandra.cql3.Terms
-
- getFunctions() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
-
- getFunctions() - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
-
- getGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
- getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
-
- getGCLogThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getGCWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getGossipMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for gossip message TCP Connections
- getGossipMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for gossip message TCP Connections
- getGossipMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getGossipMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for gossip message TCP Connections
- getGroup() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the group to which the Metric
belongs.
- getHashBuckets(IFilter.FilterKey, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
-
- getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHeapSize() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- getHeapSize() - Method in class org.apache.cassandra.dht.Token
-
- getHighestSelectivityIndexSearcher(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHintedHandoffEnabledByDC() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintedHandoffEnabledByDC() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHintedHandoffThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getHollowByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getHollowDirectByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getHost() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHostIdToEndpoint() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdToEndpoint() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of host ID to endpoint
- getHosts() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getId(String, String) - Method in class org.apache.cassandra.config.Schema
-
Lookup keyspace/ColumnFamily identifier
- getId() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getId() - Method in class org.apache.cassandra.repair.RepairSession
-
- getId() - Method in class org.apache.cassandra.thrift.CfDef
-
- getId(int) - Method in enum org.apache.cassandra.transport.DataType
-
- getId(int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- getIdentityFilter(DecoratedKey, String, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
return a QueryFilter object that includes every column in the row.
- getIdx() - Method in class org.apache.cassandra.cql3.IndexName
-
- getIfExists(UUID) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Returns a ColumnFamilyStore by cfId if it exists, null otherwise
Differently from others, this method does not throw exception if the table does not exist.
- getIfExists(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Returns a ColumnFamilyStore by ksname and cfname if it exists, null otherwise
Differently from others, this method does not throw exception if the keyspace or table does not exist.
- getIgnoreHosts(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Get the hosts to ignore as a collection of strings
- getIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getIndex_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getIndex_name() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getIndex_options() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getIndex_optionsSize() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getIndex_type() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexByName(String) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Allow access to the underlying column family store if there is one
- getIndexComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the index comparator for index backed by CFS, or null.
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexes() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
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
-
- getIndexExpressions(SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexIntervals() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getIndexIntervals() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
Returns a map of SSTable filenames to their current effective index interval.
- getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
-
- getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- 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.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Gets the position in the index file to start scanning to find the given key (at most indexInterval keys away,
modulo downsampling of the index summary).
- getIndexScanPositionFromBinarySearchResult(int, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSearchersForQuery(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Get a list of IndexSearchers from the union of expression index types
- getIndexSerializer(CFMetaData) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getIndexSerializer(CFMetaData) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getIndexSummaryCapacityInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummaryIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummaryKey(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the key for the index summary entry at `index`.
- getIndexSummaryOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummarySamplingLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the number of entries in the IndexSummary.
- getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexType(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
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
-
- getInputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCoreConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
may be null if unset
- getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeAuthProvider(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeKeepAlive(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReadConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReceiveBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeReuseAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSendBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSolinger(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLCipherSuites(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLKeystorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLKeystorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLTruststorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeSSLTruststorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputNativeTcpNodelay(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputPageRowSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSplit() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputSplitSizeInMb(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
cassandra.input.split.size will be used if the value is undefined or negative.
- getInputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInstance(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(AbstractType...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.FrozenType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(AbstractType<K>, AbstractType<V>, boolean) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.TupleType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.UserType
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
-
- getInstance(TypeSerializer<K>, TypeSerializer<V>) - Static method in class org.apache.cassandra.serializers.MapSerializer
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.SetSerializer
-
- getInt(String, Integer) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInt(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getInt(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getInt(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getIntByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getInterDCStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
-
- getInterDCStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getInterDCStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getInterDCStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- 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
-
- getIOWait() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- getIre() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- getIsDense() - Method in class org.apache.cassandra.config.CFMetaData
-
- getItemId() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getItemId() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- getItemId() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getIterator(Iterable<Memtable>, Collection<SSTableReader>, DataRange, ColumnFamilyStore, long) - Static method in class org.apache.cassandra.db.RowIteratorFactory
-
Get a row iterator over the provided memtables and sstables, between the provided keys
and filtered by the queryfilter.
- getJmxMetric(MBeanServerConnection, String, String, String) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJmxThreadPools(MBeanServerConnection) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJobThreads() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently bootstrapping into the ring.
- getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getJsonColumnValue(int, ColumnIdentifier, Collection<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.QueryOptions
-
Returns the term corresponding to column columnName
in the JSON value of bind index bindIndex
.
- getJsonDateFormatter() - Static method in class org.apache.cassandra.serializers.TimestampSerializer
-
- getKey() - Method in class org.apache.cassandra.db.BufferDecoratedKey
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getKey() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getKey() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getKey() - Method in class org.apache.cassandra.db.NativeDecoratedKey
-
- getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- getKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- getKey() - Method in class org.apache.cassandra.thrift.CqlRow
-
- getKey() - Method in class org.apache.cassandra.thrift.KeyCount
-
- getKey() - Method in class org.apache.cassandra.thrift.KeySlice
-
- getKey() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- getKey_alias() - Method in class org.apache.cassandra.thrift.CfDef
-
- getKey_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getKey_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getKey_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
-
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- getKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
-
- getKeyspace() - Method in class org.apache.cassandra.auth.FunctionResource
-
Get the name of the keyspace this resource relates to.
- getKeyspace() - Method in class org.apache.cassandra.cql3.UTName
-
- getKeyspace() - Method in class org.apache.cassandra.db.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
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- getKeyspace() - Method in class org.apache.cassandra.thrift.CfDef
-
- getKeyspaceDefinitions() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Get keyspace instance by name
- getKeyspaceMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace inner ColumnFamilies
- getKeyspaceName() - Method in class org.apache.cassandra.db.CounterMutation
-
- getKeyspaceName() - Method in interface org.apache.cassandra.db.IMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.db.Mutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getKeysType() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValidatorAsCType() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- getKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- getKSChildDirectories(String) - Static method in class org.apache.cassandra.db.Directories
-
- getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace by its name
- getLargeMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for large message) TCP Connections
- getLargeMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for large message TCP Connections
- getLargeMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessagePendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getLargeMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for large message TCP Connections
- getLargestBucketOffset() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- getLastColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns the definition of the last column.
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- getLastFlushOffset() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getLatestVersion() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
caller should not modify leavingEndpoints
- getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently leaving the ring.
- getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLegacyUserdata(String, ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- 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
-
- getLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- 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
-
- getLiveDataSize() - Method in class org.apache.cassandra.db.Memtable
-
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLiveNaturalEndpoints(Keyspace, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
This method attempts to return N endpoints that are responsible for storing the
specified key i.e for replication.
- getLiveNaturalEndpoints(Keyspace, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of live nodes in the cluster, where "liveness" is
determined by the failure detector of the node being queried.
- getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLiveRingMembers() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveRingMembers(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveSortedEndpoints(Keyspace, ByteBuffer) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- getLoadMap() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value.
- getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLoadString() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value
- getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
Please use getBroadcastAddress instead.
- getLocalClockAndCount(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the clock and the count associated with the local counter id, or (0, 0) if no such shard is present.
- getLocalComparator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.AbstractCell
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- getLocalDeletionTime() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
-
- getLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Read the host ID from the system keyspace, creating (and storing) one if
none exists.
- getLocalHostId() - Method in class org.apache.cassandra.service.StorageService
-
- getLocalHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve this hosts unique ID
- getLocalHostId() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalId() - Static method in class org.apache.cassandra.utils.CounterId
-
- getLocalizedMessage() - Method in exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
-
- getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getLocationForDisk(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories
-
Returns SSTable location which is inside given data directory.
- getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLogger(Logger, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
-
- getLoggingLevels() - Method in class org.apache.cassandra.service.StorageService
-
- getLoggingLevels() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the runtime logging levels
- getLoggingLevels() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetLoggingLevels - Class in org.apache.cassandra.tools.nodetool
-
- GetLoggingLevels() - Constructor for class org.apache.cassandra.tools.nodetool.GetLoggingLevels
-
- getLogin() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a boolean value of the login option
- getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getLong(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getLong(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getLong(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getLongByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getMapKey() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getMappings() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- getMappings() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
-
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getMax_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
-
- getMax_index_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
- 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, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getMaximumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaximumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the maximum number of sstables in queue before compaction kicks off
- getMaximumCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getMaximumCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns maximum size of compaction thread pool
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
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
- getMaxIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMaxIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the approximate number of entries the IndexSummary would contain if it were at full sampling.
- getMaxLiveCount() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getMaxNumberOfEntries() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Returns the number of entries this summary would have if it were at the full sampling level, which is equal
to the number of entries in the primary on-disk index divided by the min index interval.
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMBeanName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the MBean name for the Metric
identified by this metric name.
- getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getMemoryPoolCapacityInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getMemoryPoolCapacityInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getMemoryPoolSizeInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
Returns the actual space consumed by index summaries for all sstables.
- getMemoryPoolSizeInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
Returns the current actual off-heap memory usage of the index summaries for all non-compacting sstables.
- getMemtable_flush_after_mins() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getMemtable_flush_period_in_ms() - Method in class org.apache.cassandra.thrift.CfDef
-
- getMemtable_operations_in_millions() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getMemtable_throughput_in_mb() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getMemtableAllocatorPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableFlushPeriod() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMemtableFor(OpOrder.Group, ReplayPosition) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
get the Memtable that the ordered writeOp should be directed to
- getMemtableReservedSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
If not affected by MeteredFlusher (and handling flushing on its own), override to tell MF how much
space to reserve for this CF, i.e., how much space to subtract from `memtable_total_space_in_mb` when deciding
if other memtables should be flushed or not.
- getMerge_shards_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- getMessage() - Method in exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
-
- getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
-
- getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception message.
- getMessage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
-
- getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getMessageType() - Method in class org.apache.cassandra.net.MessageIn
-
- getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getMetadata() - Method in class org.apache.cassandra.db.Keyspace
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- getMetadata() - Method in interface org.apache.cassandra.io.util.ICompressedFile
-
- getMetadataSerializer() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- getMetricName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
- getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getMin_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
-
- getMin_index_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
- getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMinimalKey(DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
as large as necessary.
- getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the minimum number of sstables in queue before compaction kicks off
- getMinimumToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getMinIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getMinRepairedAt(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinTimestamp() - Method in class org.apache.cassandra.db.Memtable
-
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Endpoints which are migrating to the new tokens
- getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently moving in the ring.
- getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getMultiCellColumn(ColumnIdentifier) - Method in interface org.apache.cassandra.cql3.CQL3Row
-
- getMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- getMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- getMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- getMutation_mapSize() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- getMutation_mapSize() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getName() - Method in class org.apache.cassandra.auth.DataResource
-
- getName() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getName() - Method in interface org.apache.cassandra.auth.IResource
-
- getName() - Method in class org.apache.cassandra.auth.RoleResource
-
- getName() - Method in class org.apache.cassandra.cql3.RoleName
-
- getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getName() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getName() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getName() - Method in class org.apache.cassandra.db.Keyspace
-
- getName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the name of the Metric
.
- getName() - Method in enum org.apache.cassandra.repair.RepairParallelism
-
- getName() - Method in class org.apache.cassandra.thrift.CfDef
-
- getName() - Method in class org.apache.cassandra.thrift.Column
-
- getName() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getName() - Method in class org.apache.cassandra.thrift.CounterColumn
-
- getName() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- getName() - Method in class org.apache.cassandra.thrift.KsDef
-
- getName() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- getName() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getName_types() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getName_typesSize() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getNameAsString() - Method in class org.apache.cassandra.db.marshal.UserType
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Return the unique name for this index and column
to be stored in the SystemKeyspace that tracks if each column is built
- getNamesFilter(DecoratedKey, String, SortedSet<CellName>, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getNativeProtocolVersion() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
Return native version protocol of the cluster connection
- getNativeTransportMaxConcurrentConnections() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxConcurrentConnections() - Method in class org.apache.cassandra.service.StorageProxy
-
- getNativeTransportMaxConcurrentConnections() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getNativeTransportMaxConcurrentConnectionsPerIp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxConcurrentConnectionsPerIp() - Method in class org.apache.cassandra.service.StorageProxy
-
- getNativeTransportMaxFrameSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
get the (possibly cached) endpoints that should store the given Token.
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.LocalStrategy
-
We need to override this even if we override calculateNaturalEndpoints,
because the default implementation depends on token calculations but
LocalStrategy may be used before tokens are set up.
- getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
- getNaturalEndpoints(String, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNeighbors(String, Collection<Range<Token>>, Range<Token>, Collection<String>, Collection<String>) - Static method in class org.apache.cassandra.service.ActiveRepairService
-
Return all of the neighbors with whom we share the provided range.
- getNetworkInterface(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getNewEphemeralSnapshotMarkerFile(String) - Method in class org.apache.cassandra.db.Directories
-
- getNewInOrderSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNewSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
read next row
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
get next row
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
the only difference between background and maximal in LCS is that maximal is still allowed
(by explicit user request) even when compaction is disabled.
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
-
- getNextWide() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
read wide row
- getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getNonOverlappingBounds(Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
-
Retrieves non-overlapping bounds for the list of input bounds
Assume we have the following bounds
(brackets representing left/right bound):
[ ] [ ] [ ] [ ]
[ ] [ ]
This method will return the following bounds:
[ ] [ ]
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getNonSystemKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getNormalizedLoadAvg() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getNum() - Method in class org.apache.cassandra.thrift.CqlResult
-
- 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
- getOffHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getOnDiskDeserializer(DataInput, Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Returns the current file pointer of the underlying on-disk file.
- getOnDiskIterator(FileDataInput, Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, CFMetaData, Version) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, CFMetaData, Version) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getOneMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getOp() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- 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
-
- getOptions() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a map of all the options which have been set
- getOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getOptions() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getOptionsSize() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getOrCreateNextSession(InetAddress, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getOrCreateSessionById(InetAddress, int, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getOriginalIndexes(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Returns a list that can be used to translate current index summary indexes to their original index before
downsampling.
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
The original number of columns requested by the user.
- getOtcCoalescingEnoughCoalescedMessages() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtcCoalescingStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOtcCoalescingWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOutboundBindAny() - Static method in class org.apache.cassandra.config.Config
-
- getOutboundBindAny() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOutput(int) - Method in class org.apache.cassandra.cql3.selection.Selector
-
Returns the selector output.
- getOutput(int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- getOutputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
The OutputCommitter for this format does not write any data to the DFS.
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
The OutputCommitter for this format does not write any data to the DFS.
- getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- 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.CassandraStorage
-
Deprecated.
output format
- getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
output format
- getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocalDCOnly(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocation() - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- getOutputLocation() - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- getOutputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getOverlappingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getOverloadCount(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- getOwnership() - Method in class org.apache.cassandra.service.StorageService
-
- getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
given a list of tokens (representing the nodes in the cluster), returns
a mapping from "token -> %age of cluster owned by that token"
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getOwnershipByDc(NodeProbe, boolean, Map<String, String>, Map<InetAddress, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
-
- getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageableCommand(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageSize() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The pageSize for this query.
- getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The paging state for this query, or null if not relevant.
- getParallelism() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getParent() - Method in class org.apache.cassandra.auth.DataResource
-
- getParent() - Method in class org.apache.cassandra.auth.FunctionResource
-
- getParent() - Method in interface org.apache.cassandra.auth.IResource
-
Gets next resource in the hierarchy.
- getParent() - Method in class org.apache.cassandra.auth.RoleResource
-
- getParentColumnFamilyName() - Method in class org.apache.cassandra.config.CFMetaData
-
- getParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitioner() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getPartitioner() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
-
- getPartitioner() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
-
- getPartitioner() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Token
-
- getPartitioner() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
-
- getPartitioner() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitionerName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the cluster partitioner
- getPartitionerName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the cluster partitioner
- getPartitionKeyBindIndexes(CFMetaData) - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
Returns an array with the same length as the number of partition key columns for the table corresponding
to cfm.
- getPartitionKeyBounds(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the partition key bounds.
- getPartitionKeys(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the partition keys for which the data is requested.
- getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
return partition keys
- getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
return partition keys
- getPartitionSample(String, String, int, int, int, List<ColumnFamilyMetrics.Sampler>) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPassword() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return the string value of the password option
- getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getPath() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getPath() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- getPeers() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
a mutable map may be returned but caller should not modify it
- getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangesMM(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of pending ranges to endpoints that describe the ring topology
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getPermissions(IResource) - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getPermissions(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.PermissionsCache
-
- getPermissionsCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPermissionsUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPermittedToCompact() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getPermittedToCompactSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPhiValues() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiValues() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPid() - Method in class org.apache.cassandra.utils.SigarLibrary
-
- getPigType(AbstractType) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
-
Deprecated.
get pig type for the cassandra data type
- getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getPosition(RowPosition, SSTableReader.Operator, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Get position updating key cache and stats.
- getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getPosition(RowPosition, SSTableReader.Operator, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- getPosition() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPosition() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- getPositionInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
Gets the position of the actual index summary entry in our Memory attribute, 'bytes'.
- getPositionLimit() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- getPositionLimit() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- getPositionLimit() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- getPositionLimit() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPositionLimit() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
- getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getPredicate() - Method in class org.apache.cassandra.thrift.Deletion
-
- getPreferredIP(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Get preferred IP for given endpoint if it is known.
- getPrefetchedList(ByteBuffer, ColumnIdentifier, ColumnFamily) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
Returns the prefetched list with the already performed modifications.
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
-
- getPreparedForThrift(Integer) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrimaryKeyValueForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
-
- getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getPrimaryRangeForEndpointWithinDC(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
- getPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPrimaryRangesFor(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPrimaryRangesForEndpoint(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Get the "primary ranges" for the specified keyspace and endpoint.
- getPrimaryRangesWithinDC(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPrimaryRole() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- getProcessor(CassandraServer) - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getProgressCount() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getProgressPercentage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getProtectedConstructor(Class<T>, Class<?>...) - Static method in class org.apache.cassandra.utils.Hex
-
Used to get access to protected/private constructor of the specified class
- getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Used to get access to protected/private field of the specified class
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The protocol version for the query.
- getProtocolVersion() - Method in enum org.apache.cassandra.transport.DataType
-
- getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- getQuery() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- getQuery() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- getQuery() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- getQuery() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
decompose the query to store the parameters in a map
- getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
decompose the query to store the parameters in a map
- getQueryOrIdList() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getQueryState() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getRack() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Gets the stored rack for the local node, or null if none have been set yet.
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.CloudstackSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used for this node
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String repesenting the rack this endpoint belongs to
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getRack() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getRack() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRandomInt(int) - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
-
- getRandomTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Similar to getTimeUUIDFromMicros
, but randomize (using SecureRandom) the clock and sequence.
- getRandomToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- 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
-
- getRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- getRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRanges() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractRangeCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToAddressMapInLocalDC(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding listen addresses.
- getRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to end points that describe the ring topology
of a Cassandra cluster.
- getRangeTombstoneIterator(ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getRangeTombstoneIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getRangeTombstoneIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getRangeToRpcaddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding RPC addresses for a given keyspace.
- getRangeToRpcaddressMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to rpc addresses that describe the ring topology
of a Cassandra cluster.
- getRateLimiter() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Gets compaction rate limiter.
- getRateLimiter(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamManager
-
Gets streaming rate limiter.
- getRateUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
-
- getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getRawOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getRawTermForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
-
- getRawText() - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- getRawVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getRead_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
- getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getReaderFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getReadExecutor(ReadCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
-
- getReadMeter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- 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.format.SSTableReader
-
- getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
Deprecated.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Get the RecordWriter
for the given task.
- getReduced() - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- getReduced() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
-
Called after reduce() has been called for each cell sharing the same name.
- getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- getReferencesTo(Function) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getReleaseVersion(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Get release version for given endpoint.
- getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the Cassandra version.
- getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getRemoteAddress() - Method in class org.apache.cassandra.service.ClientState
-
- getRemovalStatus() - Method in class org.apache.cassandra.service.StorageService
-
Get the status of a token removal.
- getRemovalStatus() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the status of a token removal.
- getRemovalStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRepairedAt() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- getRepairedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplacementNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplacingNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getReplication_factor() - Method in class org.apache.cassandra.thrift.KsDef
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the RF based on strategy_options.
- getReplicationFactor() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- getReplicationFactor() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- getReplicationOptions() - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
-
- getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
-
- getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
-
- getRequest() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getResizeIntervalInMinutes() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- getResizeIntervalInMinutes() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
-
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- getRestoreCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestoreCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Command to execute to make an archived commitlog live again
- getRestoreDirectories() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestoreDirectories() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Directory to scan the recovery files in
- getRestorePointInTime() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestorePointInTime() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Restore mutations created up to and including this timestamp in GMT
Format: yyyy:MM:dd HH:mm:ss (2012:04:31 20:43:12)
Recovery will continue through the segment when the first client-supplied
timestamp greater than this time is encountered, but only mutations less than
or equal to this timestamp will be applied.
- getRestorePrecision() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getRestorePrecision() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
get precision of the timestamp used in the restore (MILLISECONDS, MICROSECONDS, ...)
to determine if passed the restore point in time.
- getRestrictions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.add_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.atomic_batch_mutate_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.batch_mutate_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.cas_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_cluster_name_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspace_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspaces_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_local_ring_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_partitioner_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_ring_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_schema_versions_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_snitch_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_ex_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_token_map_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_version_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_cql3_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_cql_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_prepared_cql3_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_prepared_cql_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_indexed_slices_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_multi_slice_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_paged_slice_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_range_slices_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.login_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_count_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_slice_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.prepare_cql3_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.prepare_cql_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_counter_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_cql_version_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.trace_next_query_call
-
- getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.truncate_call
-
- getResult(I, Cassandra.add_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.add
-
- getResult(I, Cassandra.atomic_batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.atomic_batch_mutate
-
- getResult(I, Cassandra.batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.batch_mutate
-
- getResult(I, Cassandra.cas_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.cas
-
- getResult(I, Cassandra.describe_cluster_name_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_cluster_name
-
- getResult(I, Cassandra.describe_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspace
-
- getResult(I, Cassandra.describe_keyspaces_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspaces
-
- getResult(I, Cassandra.describe_local_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_local_ring
-
- getResult(I, Cassandra.describe_partitioner_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_partitioner
-
- getResult(I, Cassandra.describe_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_ring
-
- getResult(I, Cassandra.describe_schema_versions_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_schema_versions
-
- getResult(I, Cassandra.describe_snitch_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_snitch
-
- getResult(I, Cassandra.describe_splits_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits
-
- getResult(I, Cassandra.describe_splits_ex_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits_ex
-
- getResult(I, Cassandra.describe_token_map_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_token_map
-
- getResult(I, Cassandra.describe_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_version
-
- getResult(I, Cassandra.execute_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql3_query
-
- getResult(I, Cassandra.execute_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql_query
-
- getResult(I, Cassandra.execute_prepared_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql3_query
-
- getResult(I, Cassandra.execute_prepared_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql_query
-
- getResult(I, Cassandra.get_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get
-
- getResult(I, Cassandra.get_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_count
-
- getResult(I, Cassandra.get_indexed_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_indexed_slices
-
- getResult(I, Cassandra.get_multi_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_multi_slice
-
- getResult(I, Cassandra.get_paged_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_paged_slice
-
- getResult(I, Cassandra.get_range_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_range_slices
-
- getResult(I, Cassandra.get_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_slice
-
- getResult(I, Cassandra.insert_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.insert
-
- getResult(I, Cassandra.login_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.login
-
- getResult(I, Cassandra.multiget_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_count
-
- getResult(I, Cassandra.multiget_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_slice
-
- getResult(I, Cassandra.prepare_cql3_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql3_query
-
- getResult(I, Cassandra.prepare_cql_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql_query
-
- getResult(I, Cassandra.remove_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove
-
- getResult(I, Cassandra.remove_counter_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove_counter
-
- getResult(I, Cassandra.set_cql_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_cql_version
-
- getResult(I, Cassandra.set_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_keyspace
-
- getResult(I, Cassandra.system_add_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_column_family
-
- getResult(I, Cassandra.system_add_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_keyspace
-
- getResult(I, Cassandra.system_drop_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_column_family
-
- getResult(I, Cassandra.system_drop_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_keyspace
-
- getResult(I, Cassandra.system_update_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_column_family
-
- getResult(I, Cassandra.system_update_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_keyspace
-
- getResult(I, Cassandra.trace_next_query_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.trace_next_query
-
- getResult(I, Cassandra.truncate_args) - Method in class org.apache.cassandra.thrift.Cassandra.Processor.truncate
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.add
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.atomic_batch_mutate
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.batch_mutate
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_cluster_name
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspace
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspaces
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_local_ring
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_partitioner
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_ring
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_schema_versions
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_snitch
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits_ex
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_token_map
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_version
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql3_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql3_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_multi_slice
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.login
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_count
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_slice
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql3_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.trace_next_query
-
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.truncate
-
- getResultMetadata(boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getResultSetIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
-
Returns the index of the specified column within the resultset
- getReturnType() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Returns the type of the values returned by the selector instances created by this factory.
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getRingVersion() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getRoleManager() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRoleName() - Method in class org.apache.cassandra.auth.RoleResource
-
- getRoles() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Get the roles that have been granted to the user via the IRoleManager
- getRoles(RoleResource, boolean) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- getRoles(RoleResource, boolean) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of a LIST ROLES query.
- getRoles(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
-
Get all roles granted to the supplied Role, including both directly granted
and inherited roles.
- getRoles(RoleResource) - Method in class org.apache.cassandra.auth.RolesCache
-
- getRolesCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRolesUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRolesValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRow(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
-
- getRow_cache_keys_to_save() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getRow_cache_provider() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getRow_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getRow_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- getRow_count() - Method in class org.apache.cassandra.thrift.CfSplit
-
- getRow_filter() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getRow_filterIterator() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getRow_filterSize() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getRowCacheClassName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRows() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getRowsIterator() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getRowsSize() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getRpc_endpoints() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getRpc_endpointsIterator() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getRpc_endpointsSize() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcaddress(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Return the rpc address associated with an endpoint as a string.
- getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcListenBacklog() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcServerType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getSamplingLevel() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getSamplingPattern(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
Gets a list L of starting indices for downsampling rounds: the first round should start with the offset
given by L[0], the second by the offset in L[1], etc.
- getSaslNegotiator() - Method in class org.apache.cassandra.transport.ServerConnection
-
- getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the saved caches dir
- getSavedTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getScanner(DataRange, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanner(SSTableReader, DataRange, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner(SSTableReader, Collection<Range<Token>>, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- getScanner() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
I/O SSTableScanner
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getScanner(DataRange) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanner(DataRange, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Returns a list of KeyScanners given sstables and a range on which to scan.
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getSchedulingValue() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
define the schema
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
schema: (value, value, value) where keys are in the front.
- getSchema() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getSchemaVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getSchemaVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the current Schema version.
- getSchemaVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
-
- getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Returns each live node's schema version
- getScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the scope of the Metric
.
- getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- getSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
-
- getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- getSelection() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getSendingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getSerial_consistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Serial consistency for conditional updates.
- getSerializedCachePath(CacheService.CacheType, String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSerializedValue(ByteBuffer, ByteBuffer, AbstractType) - Method in class org.apache.cassandra.serializers.MapSerializer
-
Given a serialized map, gets the value associated with a given key.
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ByteType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LongType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ShortType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UserType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- getServerEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
- getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
-
- getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
-
- getSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getSetOperationForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
-
- getSeverity() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSeverity() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getShort(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getShort(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- getShort(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getShortByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- getSimple(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getSliceFilter(DecoratedKey, String, Composite, Composite, boolean, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSmallMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for small message TCP Connections
- getSmallMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for small message TCP Connections
- getSmallMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getSmallMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for small message TCP Connections
- getSnapshot() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Returns a snapshot of the decaying values in this reservoir.
- getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDetails() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDetails() - Method in class org.apache.cassandra.db.Directories
-
- getSnapshotDetails() - Method in class org.apache.cassandra.service.StorageService
-
- getSnapshotDetails() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the details of all the snapshot
- getSnapshotDetails() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
-
- getSnapshotDirectory(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Returns directory to write snapshot.
- getSnapshotManifestFile(String) - Method in class org.apache.cassandra.db.Directories
-
- getSnapshotSSTableReader(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnitchName() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getSnitchName() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the snitch name of the cluster
- getSocket(EncryptionOptions, InetAddress, int, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect
- getSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect, using any local address
- getSocket(EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
-
Just create a socket
- getSocket() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Returns a reference to the underlying socket.
- getSocketThreads() - Method in class org.apache.cassandra.net.MessagingService
-
- getSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the Collection of node addresses by proximity to the given address
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a new List sorted by proximity to the given endpoint
- getSourceFrame() - Method in class org.apache.cassandra.transport.Message
-
- getSpecifications() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- getSpeculative_retry() - Method in class org.apache.cassandra.thrift.CfDef
-
- getSpeculativeRetry() - Method in class org.apache.cassandra.config.CFMetaData
-
- getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- getSplits(JobConf, int) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- getSplits(String, String, Range<Token>, int) - Method in class org.apache.cassandra.service.StorageService
-
- getSplitValues() - Method in class org.apache.cassandra.cql3.Tuples.InValue
-
- getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSLOptions(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
Get an iterator that returns columns from the given SSTable using the opened file
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given SSTable
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTableCountPerLevel() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getSSTableFormat() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getSSTablePreempiveOpenIntervalInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Returns a RestorableMeter tracking the average read rate of a particular SSTable, restoring the last-seen rate
from values in system.sstable_activity if present.
- getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTables() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetSSTables - Class in org.apache.cassandra.tools.nodetool
-
- GetSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.GetSSTables
-
- getSSTableSectionsForRanges(Collection<Range<Token>>, Collection<ColumnFamilyStore>, long, boolean) - Static method in class org.apache.cassandra.streaming.StreamSession
-
- getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesForKey(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSstablesIterated() - Method in class org.apache.cassandra.db.CollationController
-
- getSStablesPerLevelSnapshot() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- 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.thrift.ColumnSlice
-
- getStart() - Method in class org.apache.cassandra.thrift.SliceRange
-
- getStart_column() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- getStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- getStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- getStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- getStart_token() - Method in class org.apache.cassandra.thrift.CfSplit
-
- getStart_token() - Method in class org.apache.cassandra.thrift.KeyRange
-
- getStart_token() - Method in class org.apache.cassandra.thrift.TokenRange
-
- getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
- getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getStatement(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getStatement(Logger, String, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, long, TimeUnit) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatement(String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getStaticRow() - Method in interface org.apache.cassandra.cql3.CQL3Row.RowIterator
-
- getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- getStatus() - Method in class org.apache.cassandra.gms.EndpointState
-
- getStatus(ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- getStorageMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStrategy_class() - Method in class org.apache.cassandra.thrift.KsDef
-
- getStrategy_options() - Method in class org.apache.cassandra.thrift.KsDef
-
- getStrategy_optionsSize() - Method in class org.apache.cassandra.thrift.KsDef
-
- getStreamId() - Method in class org.apache.cassandra.transport.Message
-
- getStreamId() - Method in exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
-
- getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- GetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetStreamThroughput
-
- getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getString(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.AbstractCell
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.BufferCounterCell
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- getString(CellNameType) - Method in interface org.apache.cassandra.db.Cell
-
- getString(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- getString(Composite) - Method in interface org.apache.cassandra.db.composites.CType
-
Converts a composite to a user-readable string.
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a string representation of the bytes suitable for log messages
- getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FrozenType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- getString(CellNameType) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getStringTypeName() - Method in class org.apache.cassandra.cql3.UTName
-
- getSubcomparator_type() - Method in class org.apache.cassandra.thrift.CfDef
-
- getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getSummary() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
-
- getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
-
- getSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
-
- getSuperuser() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return a boolean value of the superuser option
- getSyncPoint() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
returns the Group we are waiting on - any Group with .compareTo(getSyncPoint()) <= 0
must complete before await() returns
- getTable() - Method in class org.apache.cassandra.auth.DataResource
-
- getTableForAlias(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTableInsertStatement(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTableMetadata(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Validate that keyspace
is an existing keyspace and cfName
one of its existing column family.
- getTableMetadata(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- getTableSchema(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getTaskAttemptID(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
returns TaskAttemptContext.getTaskAttemptID().
- getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- getTe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- getTempSSTablePath(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTempSSTablePath(File, SSTableFormat.Type) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getThreadLocalScratchBuffer() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getThreadPoolMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getThreadPools() - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve threadpool paths and names for threadpools with metrics.
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CASResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CfDef._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Column._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Deletion._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KsDef._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Mutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
- getThriftFieldId() - Method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
- getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getThriftFramedTransportSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getTimeout(MessagingService.Verb) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTimeout() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- getTimeout() - Method in class org.apache.cassandra.db.CounterMutation
-
- getTimeout() - Method in interface org.apache.cassandra.db.IMutation
-
- getTimeout() - Method in class org.apache.cassandra.db.Mutation
-
- getTimeout() - Method in class org.apache.cassandra.db.ReadCommand
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageIn
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageOut
-
- getTimeout() - Method in interface org.apache.cassandra.service.IReadCommand
-
- getTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts per host
- getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
-
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimestamp(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getTimestamp() - Method in class org.apache.cassandra.service.ClientState
-
This clock guarantees that updates for the same ClientState will be ordered
in the sequence seen, even if multiple updates happen in the same millisecond.
- getTimestamp() - Method in class org.apache.cassandra.service.QueryState
-
This clock guarantees that updates for the same QueryState will be ordered
in the sequence seen, even if multiple updates happen in the same millisecond.
- getTimestamp() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- getTimestamp() - Method in class org.apache.cassandra.thrift.Column
-
- getTimestamp() - Method in class org.apache.cassandra.thrift.Deletion
-
- getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Keyspace
-
- getTimestampForPaxos(long) - Method in class org.apache.cassandra.service.ClientState
-
Returns a timestamp suitable for paxos given the timestamp of the last known commit (or in progress update).
- getTimeToLive(QueryOptions, CFMetaData) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimeToLive(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimeToLive() - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- getTimeToLive() - Method in interface org.apache.cassandra.db.ExpiringCell
-
- getTimeToLive() - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID).
- getTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID) with the timestamp of @param when, in milliseconds.
- getTimeUUID(long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- getTimeUUID(long, long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a 16 byte representation of a type 1 UUID (a time-based UUID),
based on the current system time.
- getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a 100-nanoseconds precision timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a version 1 UUID using the provided timestamp and the local clock and sequence.
- getToken() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
Generate the token of a key.
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToken() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getToken() - Method in class org.apache.cassandra.dht.Token
-
- getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getToken(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.ByteOrderedPartitioner
-
- getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
-
- 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.ByteOrderedPartitioner
-
- getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenValue() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
-
- getTokenValue() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
-
- getTokenValue() - Method in class org.apache.cassandra.dht.Token
-
- getTombstoneFailureThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTombstoneFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getTombstoneFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for abandoning queries with many tombstones
- getTombstoneWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTombstoneWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
-
- getTombstoneWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for warning of queries with many tombstones
- getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getTopLevelColumns(boolean) - Method in class org.apache.cassandra.db.CollationController
-
- getTopLevelColumns(QueryFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTopLevelDeletion() - Method in class org.apache.cassandra.db.DeletionInfo
-
Returns the top-level (or "row") tombstone.
- getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getTotal() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- 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
-
- getTotalBufferSize() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- getTotalBufferSize() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalSinceLastCheck() - Method in class org.apache.cassandra.service.GCInspector
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalSizeForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- getTotalSizeReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the size of the specified partition.
- getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Total number of timeouts happened on this node
- getTotalUncompressedBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- getTraceProbability() - Method in class org.apache.cassandra.service.StorageService
-
- getTraceProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the configured tracing probability.
- getTraceProbability() - Method in class org.apache.cassandra.tools.NodeProbe
-
- GetTraceProbability - Class in org.apache.cassandra.tools.nodetool
-
- GetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.GetTraceProbability
-
- getTraceType() - Method in class org.apache.cassandra.tracing.Tracing
-
- getTracetypeQueryTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTracetypeRepairTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
-
- getTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Package protected for access from the CompactionManager.
- getTracker() - Method in class org.apache.cassandra.transport.Connection
-
- getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTriggers() - Method in class org.apache.cassandra.config.CFMetaData
-
- getTriggers() - Method in class org.apache.cassandra.thrift.CfDef
-
- getTriggersIterator() - Method in class org.apache.cassandra.thrift.CfDef
-
- getTriggersSize() - Method in class org.apache.cassandra.thrift.CfDef
-
- getTrueAllocatedSizeIn(File) - Method in class org.apache.cassandra.db.Directories
-
- getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getTruncatedAt(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncatedPosition(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncateRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTtl() - Method in class org.apache.cassandra.thrift.Column
-
- getTTL() - Method in class org.apache.cassandra.tracing.Tracing
-
- getTTL() - Method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
- getType(ByteBuffer) - Method in class org.apache.cassandra.config.UTMetaData
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- getType() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Returns the Selector
output type.
- getType() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- getType() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getType() - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- getType() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the type to which the Metric
belongs.
- getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- getType() - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- getType() - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ListSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.LongSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.MapSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.SetSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- getType() - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- getType() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getType() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
-
- getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- getUe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- getUncompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUnfinishedCompactions() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Returns a Map whose keys are KS.CF pairs and whose values are maps from sstable generation numbers to the
task ID of the compaction they were participating in.
- getUnleveledSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUnleveledSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getUnleveledSSTables() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getUnloggedBatchAcrossPartitionsWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getUnreachableMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getUnreachableNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of unreachable nodes in the cluster, as determined
by this node's failure detector.
- getUnreachableNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getUnreachableTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getUnreadableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
-
- getUnreadableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
-
- getUnrepairedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUnwritableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
-
- getUnwritableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.auth.PermissionsCache
-
- getUpdateInterval() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.auth.RolesCache
-
- getUpdateInterval() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getUpdates() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getUpdatesIterator() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getUpdatesSize() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getUpdateTimestamp() - Method in class org.apache.cassandra.gms.EndpointState
-
- getUpEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getUpEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getUsableSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Returns the number of available bytes on the specified partition.
- getUser() - Method in class org.apache.cassandra.service.ClientState
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getUserKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getUserTypeName() - Method in class org.apache.cassandra.cql3.UTName
-
- getUserTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUUID(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
-
creates a type 1 uuid from raw bytes.
- getValidatedIndexExpressions(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
get the validators
- getValidatorMap(TableInfo) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
get the validators
- getValidColumnFamilies(boolean, boolean, String...) - Method in class org.apache.cassandra.db.Keyspace
-
- getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- getValidity() - Method in class org.apache.cassandra.auth.PermissionsCache
-
- getValidity() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- getValidity() - Method in class org.apache.cassandra.auth.RolesCache
-
- getValidity() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
-
- getValue() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxGaugeMBean
-
- getValue() - Method in class org.apache.cassandra.thrift.Column
-
- getValue() - Method in enum org.apache.cassandra.thrift.Compression
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.cassandra.thrift.ConsistencyLevel
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.cassandra.thrift.CounterColumn
-
- getValue() - Method in enum org.apache.cassandra.thrift.CqlResultType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- getValue() - Method in enum org.apache.cassandra.thrift.IndexOperator
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.cassandra.thrift.IndexType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- getValue_types() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getValue_typesSize() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
-
- getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
-
- getValues() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getValues() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- getValuesIterator() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getValuesIterator() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- getValuesSize() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- getValuesSize() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- getValuesType() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getValueValidator(CellName) - Method in class org.apache.cassandra.config.CFMetaData
-
- getVariable_names() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariable_namesIterator() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariable_namesSize() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariable_types() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariable_typesIterator() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariable_typesSize() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- getVariablesForStatement(int) - Method in interface org.apache.cassandra.cql3.statements.BatchStatement.BatchVariables
-
- getVerbHandler(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
This method returns the verb handler associated with the registered
verb.
- getVerifyInfo() - Method in class org.apache.cassandra.db.compaction.Verifier
-
- getVersion() - Method in class org.apache.cassandra.config.Schema
-
- getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getVersion(String) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- getVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
- getVersion() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- 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.lifecycle.Tracker
-
- getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Return how many threads are waiting
- getWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- getWarnings() - Method in class org.apache.cassandra.transport.Message.Response
-
- getWhy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- getWhy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- getWhy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- getWindowsTimerInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWorkMap(Multimap<Range<Token>, InetAddress>, String, IFailureDetector, boolean) - Static method in class org.apache.cassandra.dht.RangeStreamer
-
- getWrappedStrategies() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- getWriteableLocation(long) - Method in class org.apache.cassandra.db.Directories
-
Returns a non-blacklisted data directory that _currently_ has writeSize
bytes as usable space.
- getWriteableLocationAsFile(long) - Method in class org.apache.cassandra.db.Directories
-
Returns a non-blacklisted data directory that _currently_ has writeSize
bytes as usable space.
- getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getWriteDirectory(long) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Return a directory where we can expect expectedWriteSize to fit.
- getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- 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
-
- getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- getWriterFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
- getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- GLOBAL_OPTIONS - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- globalCount() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
A convenience method for reporting:
- globalPartitioner() - Static method in class org.apache.cassandra.net.MessagingService
-
- globalRangeLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- globalReadLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- globalSerializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- globalWriteLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- goodRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
-
- GoogleCloudSnitch - Class in org.apache.cassandra.locator
-
A snitch that assumes an GCE region is a DC and an GCE availability_zone
is a rack.
- GoogleCloudSnitch() - Constructor for class org.apache.cassandra.locator.GoogleCloudSnitch
-
- GossipDigest - Class in org.apache.cassandra.gms
-
Contains information about a specified list of Endpoints and the largest version
of the state they have generated as known by the local endpoint.
- GossipDigestAck - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestSynMessage by an
endpoint.
- GossipDigestAck2 - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestAckMessage.
- GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- GossipDigestSyn - Class in org.apache.cassandra.gms
-
This is the first message that gets sent out as a start of the Gossip protocol in a
round.
- GossipDigestSyn(String, String, List<GossipDigest>) - Constructor for class org.apache.cassandra.gms.GossipDigestSyn
-
- GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- Gossiper - Class in org.apache.cassandra.gms
-
This module is responsible for Gossiping information for the local endpoint.
- GossiperMBean - Interface in org.apache.cassandra.gms
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
called after Gossiper instance exists immediately before it starts gossiping
- gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- GossipInfo - Class in org.apache.cassandra.tools.nodetool
-
- GossipInfo() - Constructor for class org.apache.cassandra.tools.nodetool.GossipInfo
-
- GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
-
- GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossipMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for gossip message TCP Connections
- gossipMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for gossip message TCP Connections
- gossipMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for gossip message TCP Connections
- gossipMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
-
- GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Grants a set of permissions on a resource to a role.
- grantee - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- grantee - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- grantee - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- GrantPermissionsStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantPermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
Schema alteration may result in a new database object (keyspace, table, role, function) being created capable of
having permissions GRANTed on it.
- grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during execution of GRANT ROLE query.
- GrantRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantRoleStatement
-
- group(Iterator<Cell>) - Method in interface org.apache.cassandra.cql3.CQL3Row.Builder
-
- GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
-
- GroupByPrefix(long, CellNameType, int, boolean) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
A column counter that count only 1 for all the columns sharing a
given prefix of the key.
- GroupByPrefixReversed(long, CellNameType, int, boolean) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
-
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Method for grouping similar SSTables together, This will be used by
anti-compaction to determine which SSTables should be anitcompacted
as a group.
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
DTCS should not group sstables for anticompaction - this can mix new and old data
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
Leveled compaction strategy has guarantees on the data contained within each level so we
have to make sure we only create groups of SSTables with members from the same level.
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- GT - Static variable in class org.apache.cassandra.io.sstable.format.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
-
- IAsyncCallback<T> - Interface in org.apache.cassandra.net
-
implementors of IAsyncCallback need to make sure that any public methods
are threadsafe with respect to response() being called from the message
service.
- IAsyncCallbackWithFailure<T> - Interface in org.apache.cassandra.net
-
- IAuthenticator - Interface in org.apache.cassandra.auth
-
- IAuthenticator.SaslNegotiator - Interface in org.apache.cassandra.auth
-
Performs the actual SASL negotiation for a single authentication attempt.
- IAuthorizer - Interface in org.apache.cassandra.auth
-
Primary Cassandra authorization interface.
- IBitSet - Interface in org.apache.cassandra.utils.obs
-
- ICache<K,V> - Interface in org.apache.cassandra.cache
-
This is similar to the Map interface, but requires maintaining a given capacity
and does not require put or remove to return values, which lets SerializingCache
be more efficient by avoiding deserialize except on get.
- IColumnIteratorFactory - Interface in org.apache.cassandra.db.columniterator
-
- ICompressedFile - Interface in org.apache.cassandra.io.util
-
- ICompressor - Interface in org.apache.cassandra.io.compress
-
- id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- id - Variable in class org.apache.cassandra.cql3.selection.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 class org.apache.cassandra.thrift.CfDef
-
- id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
-
- IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
-
Will read entire CF into memory.
- idFor(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- IDiskAtomFilter - Interface in org.apache.cassandra.db.filter
-
Given an implementation-specific description of what columns to look for, provides methods
to extract the desired columns from a Memtable, SSTable, or SuperColumn.
- IDiskAtomFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- IDLE_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
-
- 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.
- IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
-
Implemented by the Gossiper to convict an endpoint
based on the PHI calculated by the Failure Detector on the inter-arrival
times of the heart beats.
- IFailureDetector - Interface in org.apache.cassandra.gms
-
An interface that provides an application with the ability
to query liveness information of a node in the cluster.
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- ifile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- ifile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- IFilter - Interface in org.apache.cassandra.utils
-
- IFilter.FilterKey - Interface in org.apache.cassandra.utils
-
- IGNORE_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- IGNORE_TOMBSTONED_PARTITIONS - Static variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
A special value for compositesToGroup that indicates that partitioned tombstones should not be included in results
or count towards the limit.
- ignoredTombstonedPartitions() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
Returns true if tombstoned partitions should not be included in results or count towards the limit.
- ignoredTombstonedPartitions() - Method in class org.apache.cassandra.db.DataRange
-
Returns true if tombstoned partitions should not be included in results or count towards the limit.
- ignores - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- ignoreTombstonedPartitions() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
Returns true if tombstoned partitions should not be included in results or count towards the limit, false otherwise.
- IInternodeAuthenticator - Interface in org.apache.cassandra.auth
-
- ILatencySubscriber - Interface in org.apache.cassandra.locator
-
- IMeasurableMemory - Interface in org.apache.cassandra.cache
-
- IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
-
- IMessageSink - Interface in org.apache.cassandra.net
-
- IMetadataComponentSerializer<T extends MetadataComponent> - Interface in org.apache.cassandra.io.sstable.metadata
-
Metadata component serializer
- IMetadataSerializer - Interface in org.apache.cassandra.io.sstable.metadata
-
Interface for SSTable metadata serializer
- 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(List<ColumnDefinition>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
-
- IN(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
-
- includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.RangeTombstone
-
- IncludingExcludingBounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
-
AbstractBounds containing only its left endpoint: [left, right).
- IncludingExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.IncludingExcludingBounds
-
- inclusive - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
-
- inclusiveLeft() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- inclusiveLeft() - Method in class org.apache.cassandra.dht.Bounds
-
- inclusiveLeft() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- inclusiveLeft() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- inclusiveLeft() - Method in class org.apache.cassandra.dht.Range
-
- inclusiveLowerBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- inclusiveRight() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- inclusiveRight() - Method in class org.apache.cassandra.dht.Bounds
-
- inclusiveRight() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- inclusiveRight() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- inclusiveRight() - Method in class org.apache.cassandra.dht.Range
-
- inclusiveUpperBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- IncomingFileMessage - Class in org.apache.cassandra.streaming.messages
-
IncomingFileMessage is used to receive the part(or whole) of a SSTable data file.
- IncomingFileMessage(SSTableWriter, FileMessageHeader) - Constructor for class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- IncomingStreamingConnection - Class in org.apache.cassandra.net
-
Thread to consume stream init messages.
- IncomingStreamingConnection(int, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingStreamingConnection
-
- IncomingTcpConnection - Class in org.apache.cassandra.net
-
- IncomingTcpConnection(int, boolean, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
-
- inCondition(ColumnDefinition, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- inCondition(ColumnDefinition, Term, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
-
- incrCompactionSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- incrCounter(Enum<?>, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- incrCounter(String, String, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- incrCreatedHints(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- incremental_backups - Variable in class org.apache.cassandra.config.Config
-
- INCREMENTAL_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- incrementCounter(Counter, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Increment the counter.
- incrementDroppedMessages(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementDroppedMessages(MessagingService.Verb, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- incrementReadCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Increment the total row read count and read rate for this SSTable.
- incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- incrManualSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- index(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
Index the given row.
- index_clause - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- INDEX_ENTRIES_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The name of the option used to specify that the index is on the collection (map) entries.
- index_interval - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- index_interval - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- INDEX_KEYS_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The name of the option used to specify that the index is on the collection keys.
- index_name - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- index_options - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- index_summary_capacity_in_mb - Variable in class org.apache.cassandra.config.Config
-
- index_summary_resize_interval_in_minutes - Variable in class org.apache.cassandra.config.Config
-
- index_type - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- INDEX_VALUES_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The name of the option used to specify that the index is on the collection values.
- indexBuilder - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- indexCfs - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- IndexClause - Class in org.apache.cassandra.thrift
-
- IndexClause() - Constructor for class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- IndexClause(List<IndexExpression>, ByteBuffer, int) - Constructor for class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- IndexClause(IndexClause) - Constructor for class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
Performs a deep copy on other.
- IndexClause._Fields - Enum in org.apache.cassandra.thrift
-
Deprecated.
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- indexColumnFamilyName(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
generate a column family name for an index corresponding to the given column.
- indexComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- indexComparator() - Method in interface org.apache.cassandra.db.composites.CType
-
- IndexedEntry(DecoratedKey, CellName, long, ByteBuffer, Composite) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- IndexedEntry(DecoratedKey, CellName, long, ByteBuffer, Composite, ByteBuffer) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryCollectionKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryPrefix - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexEntry - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexer - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns true if the provided cell name is indexed by this secondary index.
- indexes(ColumnDefinition) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns true if the provided column definition is indexed by this secondary index.
- indexes(CellName, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- IndexExpression - Class in org.apache.cassandra.db
-
- IndexExpression(ByteBuffer, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.IndexExpression
-
- IndexExpression - Class in org.apache.cassandra.thrift
-
- IndexExpression() - Constructor for class org.apache.cassandra.thrift.IndexExpression
-
- IndexExpression(ByteBuffer, IndexOperator, ByteBuffer) - Constructor for class org.apache.cassandra.thrift.IndexExpression
-
- IndexExpression(IndexExpression) - Constructor for class org.apache.cassandra.thrift.IndexExpression
-
Performs a deep copy on other.
- IndexExpression._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- indexExpressionsFromThrift(List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- indexFor(CellName, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(Composite, List<IndexHelper.IndexInfo>, CType, boolean, int) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
The index of the IndexInfo in which a scan starting with @name should begin.
- IndexHelper - Class in org.apache.cassandra.io.sstable
-
Provides helper to serialize, deserialize and use column indexes.
- IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
-
- IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
-
- IndexHelper.IndexInfo.Serializer - Class in org.apache.cassandra.io.sstable
-
- IndexInfo(Composite, Composite, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- indexLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- IndexName - Class in org.apache.cassandra.cql3
-
- IndexName() - Constructor for class org.apache.cassandra.cql3.IndexName
-
- indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- IndexNotAvailableException - Exception in org.apache.cassandra.db.index
-
Thrown if a secondary index is not currently available.
- IndexNotAvailableException(String) - Constructor for exception org.apache.cassandra.db.index.IndexNotAvailableException
-
Creates a new IndexNotAvailableException
for the specified index.
- IndexOperator - Enum in org.apache.cassandra.thrift
-
- indexOption() - Method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
-
- IndexPropDefs - Class in org.apache.cassandra.cql3.statements
-
- IndexPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- indexReverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- indexReverseComparator() - Method in interface org.apache.cassandra.db.composites.CType
-
- indexRow(ByteBuffer, ColumnFamily, OpOrder.Group) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
When building an index against existing data, add the given row to the index
- indexRow(DecoratedKey, ColumnFamilyStore, Set<String>) - Static method in class org.apache.cassandra.db.Keyspace
-
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- indexSummary - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- IndexSummary - Class in org.apache.cassandra.io.sstable
-
- IndexSummary(IPartitioner, Memory, int, Memory, long, int, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
-
- IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder(long, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- IndexSummaryBuilder.ReadableBoundary - Class in org.apache.cassandra.io.sstable
-
Represents a boundary that is guaranteed fully readable in the summary, index file and data file.
- IndexSummaryManager - Class in org.apache.cassandra.io.sstable
-
Manages the fixed-size memory pool for index summaries, periodically resizing them
in order to give more memory to hot sstables and less memory to cold sstables.
- IndexSummaryManagerMBean - Interface in org.apache.cassandra.io.sstable
-
- indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Off heap memory used by index summary
- indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Off heap memory used by index summary
- IndexSummaryRedistribution - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryRedistribution(List<SSTableReader>, Map<UUID, LifecycleTransaction>, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- IndexTarget - Class in org.apache.cassandra.cql3.statements
-
- IndexTarget.Raw - Class in org.apache.cassandra.cql3.statements
-
- IndexTarget.TargetType - Enum in org.apache.cassandra.cql3.statements
-
- IndexType - Enum in org.apache.cassandra.config
-
- IndexType - Enum in org.apache.cassandra.thrift
-
- indexValue - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- inDirectory(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The directory where to write the sstables.
- inDirectory(File) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The directory where to write the sstables (mandatory option).
- InetAddressSerializer - Class in org.apache.cassandra.serializers
-
- InetAddressSerializer() - Constructor for class org.apache.cassandra.serializers.InetAddressSerializer
-
- InetAddressType - Class in org.apache.cassandra.db.marshal
-
- inEventLoop(Thread) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- info - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
- Info - Class in org.apache.cassandra.tools.nodetool
-
- Info() - Constructor for class org.apache.cassandra.tools.nodetool.Info
-
- info(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- info(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
-
- info(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
-
- info(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
-
- init() - Method in class org.apache.cassandra.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.
- init(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- initCf(CFMetaData, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
adds a cf to internal structures, ends up creating disk files).
- initcond - Variable in class org.apache.cassandra.cql3.functions.UDAggregate
-
- initDatabaseDescriptor() - Static method in class org.apache.cassandra.tools.Util
-
This is used by standalone tools to force static initialization of DatabaseDescriptor, and fail if configuration
is bad.
- initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- initial_token - Variable in class org.apache.cassandra.config.Config
-
- INITIAL_VALUE_NANOS - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- initialComparator - Variable in class org.apache.cassandra.db.Memtable
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- initialCompressedBufferLength(int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- initialCondition() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
Deprecated.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- initialized() - Method in class org.apache.cassandra.utils.SigarLibrary
-
- initializeFromMessage(MessageIn<?>) - Method in class org.apache.cassandra.tracing.Tracing
-
Determines the tracing context from a message.
- initializeNodeUnsafe(InetAddress, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
-
- initiate() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up incoming message handler and initiate streaming.
- initiateOnReceivingSide(IncomingStreamingConnection, boolean, int) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up outgoing message handler on receiving side.
- initiator - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- initiator - Variable in class org.apache.cassandra.repair.Validator
-
- initReceivingSide(int, UUID, String, InetAddress, IncomingStreamingConnection, boolean, int, boolean, boolean) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
-
- initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
Methods to get the column family schema from Cassandra
- initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
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
-
- initSigarLibrary - Static variable in class org.apache.cassandra.service.StartupChecks
-
- injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- InMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.InMarker
-
- inOrderDeletionTester() - Method in class org.apache.cassandra.db.ColumnFamily
-
- inOrderTester() - Method in class org.apache.cassandra.db.DeletionInfo
-
- inOrderTester(boolean) - Method in class org.apache.cassandra.db.DeletionInfo
-
- InOrderTester() - Constructor for class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- INotification - Interface in org.apache.cassandra.notifications
-
Created by IntelliJ IDEA.
- INotificationConsumer - Interface in org.apache.cassandra.notifications
-
- inProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- inputVersion - Variable in class org.apache.cassandra.streaming.StreamReader
-
- INRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.INRaw
-
- INRaw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.INRaw
-
- inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- insert(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- insert(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
insert a column to the index
- insert(Cell) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when constructing the index against pre-existing data
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- insert() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Insert a Column at the given column_parent.column_family and optional column_parent.super_column.
- insert() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.insert
-
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- insert_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
- insert_args(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
- insert_args(Cassandra.insert_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
Performs a deep copy on other.
- insert_call(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
-
- insert_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
- insert_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
- insert_result(Cassandra.insert_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
Performs a deep copy on other.
- inspectCommitLogThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- inspectJvmOptions - Static variable in class org.apache.cassandra.service.StartupChecks
-
- inspectThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
Certain Throwables and Exceptions represent "Die" conditions for the server.
- instance - Static variable in class org.apache.cassandra.config.Schema
-
- instance - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- instance - Static variable in class org.apache.cassandra.db.BatchlogManager
-
- instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
-
- instance - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- instance() - Static method in class org.apache.cassandra.db.context.CounterContext
-
- instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
- instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BooleanType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.ByteType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LongType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.ShortType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.SimpleDateType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
-
- instance - Static variable in class org.apache.cassandra.db.SizeEstimatesRecorder
-
- instance - Static variable in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- instance - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- instance - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- instance - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- instance - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- instance - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- instance - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- instance - Static variable in class org.apache.cassandra.gms.Gossiper
-
- instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
-
- instance - Static variable in class org.apache.cassandra.io.compress.LZ4Compressor
-
- instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
-
- instance - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
-
- instance - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- instance - Static variable in class org.apache.cassandra.metrics.ClientMetrics
-
- instance() - Static method in class org.apache.cassandra.net.MessagingService
-
- instance - Static variable in class org.apache.cassandra.serializers.AsciiSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.ByteSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.BytesSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.ShortSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- instance - Static variable in class org.apache.cassandra.service.CacheService
-
- instance - Static variable in class org.apache.cassandra.service.ClientWarn
-
- instance - Static variable in class org.apache.cassandra.service.FileCacheService
-
- instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- instance - Static variable in class org.apache.cassandra.service.PendingRangeCalculatorService
-
- instance - Static variable in class org.apache.cassandra.service.StorageProxy
-
- instance - Static variable in class org.apache.cassandra.service.StorageService
-
- instance - Static variable in class org.apache.cassandra.streaming.StreamManager
-
- instance - Static variable in class org.apache.cassandra.thrift.ThriftSessionManager
-
- instance - Static variable in class org.apache.cassandra.tracing.Tracing
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- instance - Static variable in class org.apache.cassandra.triggers.TriggerExecutor
-
- instance() - Static method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
-
- instance - Static variable in class org.apache.cassandra.utils.CRC32Factory
-
- instance - Static variable in class org.apache.cassandra.utils.memory.HeapAllocator
-
- instance - Static variable in class org.apache.cassandra.utils.SigarLibrary
-
- instanceId - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- instanceOrConstruct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Constructs an instance of the given class, which must have a no-arg or default constructor.
- InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
-
Wraps an ICache in requests + hits tracking.
- InstrumentingCache(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
-
- Int32Serializer - Class in org.apache.cassandra.serializers
-
- Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
-
- Int32Type - Class in org.apache.cassandra.db.marshal
-
- integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- IntegerSerializer - Class in org.apache.cassandra.serializers
-
- IntegerSerializer() - Constructor for class org.apache.cassandra.serializers.IntegerSerializer
-
- IntegerType - Class in org.apache.cassandra.db.marshal
-
- inter_dc_stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- inter_dc_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
-
- internalClose() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Close the segment file.
- internalClose() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment
-
- internalClose() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
-
- internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- internalOpen(Descriptor, Set<Component>, CFMetaData, IPartitioner, SegmentedFile, SegmentedFile, IndexSummary, IFilter, long, StatsMetadata, SSTableReader.OpenReason) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).
- internalSize() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- internedIds - Variable in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- internode_authenticator - Variable in class org.apache.cassandra.config.Config
-
- internode_compression - Variable in class org.apache.cassandra.config.Config
-
- internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- internode_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internode_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by any entity wanting to interrogate the status of an endpoint.
- interrupt() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- interruptCompactionFor(Iterable<CFMetaData>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Try to stop all of the compactions for given ColumnFamilies.
- interruptCompactionForCFs(Iterable<ColumnFamilyStore>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
this = this AND other
- intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(List<ByteBuffer>, List<ByteBuffer>, CellNameType, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
return true if @param range intersects any of the given @param ranges
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
-
- intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- Interval<C,D> - Class in org.apache.cassandra.utils
-
- Interval(C, C, D) - Constructor for class org.apache.cassandra.utils.Interval
-
- intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
-
- intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
-
- intervalTree - Variable in class org.apache.cassandra.db.lifecycle.View
-
- IntervalTree<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- IntervalTree(Collection<I>) - Constructor for class org.apache.cassandra.utils.IntervalTree
-
- IntervalTree.Serializer<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- invalidate() - Method in class org.apache.cassandra.auth.PermissionsCache
-
- invalidate() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- invalidate() - Method in class org.apache.cassandra.auth.RolesCache
-
- invalidate() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
-
- invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
call when dropping or renaming a CF.
- invalidate(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidate() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Remove the index and unregisters this index's mbean if one exists
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Remove the index
- invalidate(FileCacheService.CacheKey, String) - Method in class org.apache.cassandra.service.FileCacheService
-
- invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Invalidates the ranges containing the given token.
- invalidateCachedRings() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- invalidateCachedRow(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCounterCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateCounterCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateCounterCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- invalidateCounterCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateCounterCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateCounterCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
-
- invalidateCounterCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidateKeyCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateKeyCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the key cache; for use after invalidating row cache
- invalidateKeyCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateKeyCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateKeyCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
-
- invalidateKeyCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidateRowCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- invalidateRowCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateRowCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the row cache; for use after bulk loading via BinaryMemtable
- invalidateRowCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidateRowCache - Class in org.apache.cassandra.tools.nodetool
-
- InvalidateRowCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateRowCache
-
- invalidateRowCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- invalidRequest(String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Returns an InvalidRequestException
with the specified message.
- InvalidRequestException - Exception in org.apache.cassandra.exceptions
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
-
- InvalidRequestException - Exception in org.apache.cassandra.thrift
-
Invalid request could mean keyspace or column family does not exist, required parameters are missing, or a parameter is malformed.
- InvalidRequestException() - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
-
- InvalidRequestException(InvalidRequestException) - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
-
Performs a deep copy on other.
- InvalidRequestException._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- 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.
- InValue(List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.Tuples.InValue
-
- inverse() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- inverse() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- INVERTED_ORDER - Static variable in class org.apache.cassandra.utils.memory.MemoryUtil
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- InWithMarker(List<ColumnDefinition>, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
-
- InWithMarker(ColumnDefinition, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
-
- InWithValues(List<ColumnDefinition>, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
-
- InWithValues(ColumnDefinition, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
-
- IOWAIT_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- IPartitioner - Interface in org.apache.cassandra.dht
-
- IPartitionerDependentSerializer<T> - Interface in org.apache.cassandra.dht
-
Versioned serializer where the serialization depends on partitioner.
- ipOrDns() - Method in class org.apache.cassandra.tools.nodetool.HostStat
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.add_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- ire - Variable in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- 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
-
- IRoleManager - Interface in org.apache.cassandra.auth
-
Responsible for managing roles (which also includes what
used to be known as users), including creation, deletion,
alteration and the granting and revoking of roles to other
roles.
- IRoleManager.Option - Enum in org.apache.cassandra.auth
-
Supported options for CREATE ROLE/ALTER ROLE (and
CREATE USER/ALTER USER, which are aliases provided
for backwards compatibility).
- IRowCacheEntry - Interface in org.apache.cassandra.cache
-
- IRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- isAcknowledged_by_batchlog() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
in case of atomic_batch_mutate method this field tells if the batch
was written to the batchlog.
- isActive - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
pause/resume/getNextBackgroundTask must synchronize.
- isAffectedByMeteredFlusher() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
-
- isAfter(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
- isAggregate() - Method in interface org.apache.cassandra.cql3.functions.Function
-
Checks whether the function is an aggregate function or not.
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeAggregateFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Checks if this Selector
is creating aggregates.
- isAggregateSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates selectors instances that creates aggregates.
- isAlive() - Method in class org.apache.cassandra.gms.EndpointState
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Failure Detector's knowledge of whether a node is up or
down.
- isAlive - Static variable in interface org.apache.cassandra.net.IAsyncCallback
-
- isAlwaysEmpty(CellNameType, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
If IAuthenticator doesn't require authentication, this method may return true.
- isAssignable() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
- isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAutoCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isAutoCompactionDisabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAvailable() - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- isAvailable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isBefore(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isBlocking() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
- isBlockingSignal() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
register to be signalled when a barrier waiting on us is, or maybe, blocking general progress,
so we should try more aggressively to progress
- isBlockingSignal(WaitQueue.Signal) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
-
wrap the provided signal to also be signalled if the operation gets marked blocking
- isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
-
- IsBootstrappingException - Exception in org.apache.cassandra.exceptions
-
- IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
-
- isByteOrderComparable - Variable in class org.apache.cassandra.db.composites.AbstractCType
-
- isByteOrderComparable(Iterable<AbstractType<?>>) - Static method in class org.apache.cassandra.db.composites.AbstractCType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.MapType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.SetType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.TimeType
-
- isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- isCallableWrtNullable(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
-
- isCalledOnNullInput() - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
-
- isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isCancelled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
- isClean() - Method in class org.apache.cassandra.db.Memtable
-
- isCleanedUp() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- isCleanerAvailable() - Static method in class org.apache.cassandra.io.util.FileUtils
-
- isClientMode() - Static method in class org.apache.cassandra.config.Config
-
- isClusteringColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCollection() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isCollectionCell() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- isCollectionCell() - Method in interface org.apache.cassandra.db.composites.CellName
-
- isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
-
- isCollectionCell() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- isCollectionCell() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- isColumnRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the query returns a range of columns.
- isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactValue() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- isCompatibleWith(Operation.RawUpdate) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- isCompatibleWith(CType) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- isCompatibleWith(CType) - Method in interface org.apache.cassandra.db.composites.CType
-
See AbstractType#isCompatibleWith.
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns true if this comparator is compatible with the provided
previous comparator, that is if previous can safely be replaced by this.
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
A version of isCompatibleWith() to deal with non-multicell (frozen) collections
- isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
-
- isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- isComplete() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
-
- isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
-
- isCompound() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- isCompound() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- isCompound() - Method in class org.apache.cassandra.db.composites.CompoundCType
-
- isCompound() - Method in interface org.apache.cassandra.db.composites.CType
-
Returns whether this is a "truly-composite" underneath.
- isCompound() - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- isCompressed() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- isContains() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a CONTAINS
.
- isContains() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isContains() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- isContains() - Method in class org.apache.cassandra.db.IndexExpression
-
Checks if the operator of this IndexExpression
is a CONTAINS
operator.
- isContainsKey() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a CONTAINS_KEY
.
- isContainsKey() - Method in class org.apache.cassandra.db.IndexExpression
-
Checks if the operator of this IndexExpression
is a CONTAINS_KEY
operator.
- isCounter() - Method in class org.apache.cassandra.config.CFMetaData
-
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isCounter() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isCounter() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCounter() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- isCounterCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isCountRows(Function) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
-
Checks if the specified function is the count rows (e.g.
- isCQL3Table() - Method in class org.apache.cassandra.config.CFMetaData
-
- isCustom - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- isDaemonInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isDataAvailable(String, Token) - Method in class org.apache.cassandra.dht.StreamStateStore
-
Check if given token's data is available in this node.
- isDatacenterLocal() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isDataPresent() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RowDataResolver
-
- isDataPresent() - Method in class org.apache.cassandra.service.RowDigestResolver
-
- isDeadState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- isDeleted(Cell) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
-
- isDeleted(Cell) - Method in class org.apache.cassandra.db.DeletionInfo
-
Return whether a given cell is deleted by the container having this deletion info.
- isDeleted(OnDiskAtom) - Method in class org.apache.cassandra.db.DeletionTime
-
- isDeleted(Cell) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
-
Tests if the provided column is deleted by one of the tombstone
tracked by this tracker.
- isDeleted(Cell) - Method in class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- isDeleted(Cell) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns whether the given name/timestamp pair is deleted by one of the tombstone
of this RangeTombstoneList.
- isDense(Boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
- isDense() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Whether or not the cell names for this type are dense.
- isDense() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- isDense() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- isDense() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- isDense() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
-
- isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
-
- isDirty - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- isDistinct - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- isDummy() - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- isDurable_writes() - Method in class org.apache.cassandra.thrift.KsDef
-
- isEmpty() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return true if there are no options with values set, false otherwise
- isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
-
- isEmpty() - Method in class org.apache.cassandra.cql3.ResultSet
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- isEmpty() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns true if this contains no columns or deletion info
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isEmpty() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
-
- isEmpty() - Method in class org.apache.cassandra.db.composites.AbstractComposite
-
- isEmpty() - Method in interface org.apache.cassandra.db.composites.Composite
-
- isEmpty() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
-
Checks if this builder is empty.
- isEmpty() - Method in class org.apache.cassandra.db.Mutation
-
- isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- isEmpty(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
- isEmpty() - Method in class org.apache.cassandra.streaming.StreamPlan
-
- isEmpty() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- isEmpty(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- isEmpty() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- isEmpty() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.IntervalTree
-
- isEmpty() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns true if there are no set bits
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns
true
for types where empty should be handled like
null
like
Int32Type
.
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LongType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- isEnabled() - Method in class org.apache.cassandra.cache.CachingOptions.KeyCache
-
- isEnabled() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
-
- isEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
-
- isEncryptedChannel(InetAddress) - Static method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- isEnd() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- isEOF() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- isEQ() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a EQ
.
- isEQ() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
-
- isEQ() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
-
- ISerializer<T> - Interface in org.apache.cassandra.io
-
- isExactMatch() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
- 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.
- isExistingRole(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- isExistingRole(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Return true is a Role with the given name exists in the system.
- isExpired() - Method in class org.apache.cassandra.db.Memtable
-
- isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isFailureCallback() - Method in class org.apache.cassandra.net.CallbackInfo
-
- isFailureResponse() - Method in class org.apache.cassandra.net.MessageIn
-
- isFilterFullyCoveredBy(IDiskAtomFilter, ColumnFamily, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- isFrozenCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isFullRowSlice(SliceQueryFilter) - Static method in class org.apache.cassandra.db.DataRange
-
- isFullyCoveredBy(ColumnFamily, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
Whether the provided cf, that is assumed to contain the head of the
partition, contains enough data to cover this filter.
- isFullyCoveredBy(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- isFullyCoveredBy(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- isGcAble(int) - Method in class org.apache.cassandra.db.DeletionTime
-
- isGlobal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isGlobal() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isGlobal - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- isGossipOnlyMember(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isGossipRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isGossipRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isGossipRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isHandoffEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isHeadFilter() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- isHeadFilter() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- isHeadFilter() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- isIN() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a IN
.
- isIN() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
-
- isIN() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isIN() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
-
- isInBounds(T, Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- isInclusive(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Checks if the specified bound is inclusive or not.
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
-
- isIncremental - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- isIncremental() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isIncremental - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- isIncremental - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isIncremental() - Method in class org.apache.cassandra.streaming.StreamSession
-
- isIncrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.service.StorageService
-
- isIncrementalBackupsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
true if this CFS contains secondary index data
- isIndexBuilt(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Checks if the index for specified column is fully built
- isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isIndexed() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- isIndexEntryStale(ByteBuffer, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- isIndexNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isInitialized() - Method in class org.apache.cassandra.service.StorageService
-
- isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isInLocalDCOnly() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns if this map only support inserts in reverse order.
- isInShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
- isInShutdownHook() - Method in class org.apache.cassandra.service.StorageService
-
- isInterestedIn(String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
-
- isInterestedIn(String) - Method in class org.apache.cassandra.tools.RepairRunner
-
- isInterestedIn(String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
-
- isInternal - Variable in class org.apache.cassandra.service.ClientState
-
- 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
-
- isJson - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- isKeyCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isKeyRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the query request a range of partition keys.
- isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- isLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
-
- isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isListening() - Method in class org.apache.cassandra.net.MessagingService
-
- isLive() - Method in class org.apache.cassandra.db.AbstractCell
-
- isLive(long) - Method in class org.apache.cassandra.db.AbstractCell
-
- isLive() - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- isLive(long) - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- isLive() - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- isLive(long) - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- isLive() - Method in interface org.apache.cassandra.db.Cell
-
- isLive(long) - Method in interface org.apache.cassandra.db.Cell
-
- isLive() - Method in class org.apache.cassandra.db.DeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- isLive() - Method in class org.apache.cassandra.db.DeletionTime
-
Returns whether this DeletionTime is live, that is deletes no columns.
- isLive() - Method in class org.apache.cassandra.db.Memtable
-
- isLive() - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- isLive(long) - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- isLive() - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- isLive(long) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- isLive() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- isLocal(InetAddress) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isLocal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isLocalId() - Method in class org.apache.cassandra.utils.CounterId
-
- isMap() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
Checks if this collection is Map.
- isMarkedCompacted() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
-
- isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isMinimum() - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in interface org.apache.cassandra.db.RowPosition
-
- isMinimum() - Method in interface org.apache.cassandra.dht.RingPosition
-
- isMinimum() - Method in class org.apache.cassandra.dht.Token
-
- isMinimum() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- isMinimumBound - Variable in class org.apache.cassandra.dht.Token.KeyBound
-
- isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.ListType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.MapType
-
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.SetType
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if this relation apply to multiple columns.
- isMultiColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
- isMultiColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isNative() - Method in interface org.apache.cassandra.cql3.functions.Function
-
Checks whether the function is a native/hard coded one or not.
- isNative() - Method in class org.apache.cassandra.cql3.functions.NativeFunction
-
- isNative() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- isNative() - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isNonCompositeSliceWithExclusiveBounds() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
-
- isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Checks if this restriction will prevent the query to return any rows.
- isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
-
- isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- isNotReturningAnyRows(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Checks if the query will never return any rows.
- isNullOrEmpty(AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
-
- isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
indicates if the reader has been marked for obsoletion
- isOffline() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- isOnAllComponents() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.add
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.atomic_batch_mutate
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.batch_mutate
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_cluster_name
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspaces
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_local_ring
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_partitioner
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_ring
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_schema_versions
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_snitch
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits_ex
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_token_map
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_version
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_multi_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.login
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_count
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.trace_next_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.truncate
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.add
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.atomic_batch_mutate
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.batch_mutate
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.cas
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_cluster_name
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspaces
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_local_ring
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_partitioner
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_ring
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_schema_versions
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_snitch
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits_ex
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_token_map
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.describe_version
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_count
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_indexed_slices
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_multi_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_paged_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_range_slices
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.get_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.insert
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.login
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_count
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.multiget_slice
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql3_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.remove_counter
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_cql_version
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.set_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_add_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_column_family
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.system_update_keyspace
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.trace_next_query
-
- isOneway() - Method in class org.apache.cassandra.thrift.Cassandra.Processor.truncate
-
- isOnToken() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isOnToken() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- isOpen() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Checks whether the socket is connected.
- isOutgoingConnected() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- isPaging - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- isPartitionKey() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isPartOfCellName() - Method in class org.apache.cassandra.config.ColumnDefinition
-
Whether the name of this definition is serialized in the cell nane, i.e.
- isPaxos_in_progress() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
for the CAS method, this field tells if we timed out during the paxos
protocol, as opposed to during the commit of our update
- isPopulate_io_cache_on_flush() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- isPrefixOf(CType, Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- isPrefixOf(CType, Composite) - Method in class org.apache.cassandra.db.composites.AbstractComposite
-
- isPrefixOf(CType, Composite) - Method in interface org.apache.cassandra.db.composites.Composite
-
- isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
-
- isPresent(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
-
- isPrimaryKeyColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isPrimaryRange() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isPurged() - Method in class org.apache.cassandra.config.CFMetaData
-
- isQueryable() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Checks if the index is ready.
- isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
-
- isReceiving() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- isRegular() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isRepaired() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isReplacingSameAddress() - Static method in class org.apache.cassandra.service.StorageService
-
- isReplicate_on_write() - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- isReversed() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- isReversed() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isReversed() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isReversed() - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- isReversed() - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- isReversed() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- isReversed() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- isReversed() - Method in class org.apache.cassandra.thrift.SliceRange
-
- isReversedType() - Method in class org.apache.cassandra.cql3.ColumnSpecification
-
- isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isRowCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isRpcReady() - Method in class org.apache.cassandra.gms.EndpointState
-
- isRpcReady(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Returns whether the server is currently running.
- isRunning() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- isRunning() - Method in class org.apache.cassandra.transport.Server
-
- isSafeForBootstrap(InetAddress, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
-
Check if this endpoint can safely bootstrap into the cluster.
- isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- isSameCQL3RowAs(CellNameType, CellName) - Method in interface org.apache.cassandra.db.composites.CellName
-
Whether this cell is part of the same CQL3 row as the other cell.
- isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
-
- isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
-
- isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, Composite, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, Composite, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- isSatisfiedByValue(ByteBuffer, Cell, AbstractType<?>, Operator, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- isSecondaryIndex() - Method in class org.apache.cassandra.config.CFMetaData
-
The '.' char is the only way to identify if the CFMetadata is for a secondary index
- isSerialConsistency() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSet(AuthenticationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(AuthenticationRequest._Fields) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(AuthorizationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CASResult._Fields) - Method in class org.apache.cassandra.thrift.CASResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.add_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.add_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.atomic_batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.atomic_batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.cas_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.cas_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_cluster_name_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_cluster_name_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_keyspaces_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_keyspaces_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_local_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_local_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_partitioner_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_partitioner_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_schema_versions_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_schema_versions_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_snitch_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_snitch_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_splits_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_splits_ex_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_splits_ex_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_splits_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_token_map_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_token_map_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.describe_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_prepared_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_prepared_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_prepared_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.execute_prepared_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_indexed_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_indexed_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_multi_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_multi_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_paged_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_paged_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_range_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_range_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.get_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.insert_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.insert_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.login_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.login_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.multiget_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.multiget_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.multiget_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.multiget_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.prepare_cql3_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.prepare_cql3_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.prepare_cql_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.prepare_cql_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.remove_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.remove_counter_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.remove_counter_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.remove_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.set_cql_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.set_cql_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.set_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.set_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_add_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_add_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_add_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_add_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_drop_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_drop_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_drop_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_drop_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_update_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_update_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_update_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.system_update_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.trace_next_query_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.trace_next_query_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.truncate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Cassandra.truncate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CfDef._Fields) - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CfSplit._Fields) - Method in class org.apache.cassandra.thrift.CfSplit
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Column._Fields) - Method in class org.apache.cassandra.thrift.Column
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnDef._Fields) - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnOrSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnParent._Fields) - Method in class org.apache.cassandra.thrift.ColumnParent
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnPath._Fields) - Method in class org.apache.cassandra.thrift.ColumnPath
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnSlice._Fields) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CounterColumn._Fields) - Method in class org.apache.cassandra.thrift.CounterColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CounterSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CqlMetadata._Fields) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CqlPreparedResult._Fields) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CqlResult._Fields) - Method in class org.apache.cassandra.thrift.CqlResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CqlRow._Fields) - Method in class org.apache.cassandra.thrift.CqlRow
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Deletion._Fields) - Method in class org.apache.cassandra.thrift.Deletion
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(EndpointDetails._Fields) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IndexClause._Fields) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IndexExpression._Fields) - Method in class org.apache.cassandra.thrift.IndexExpression
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(InvalidRequestException._Fields) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeyCount._Fields) - Method in class org.apache.cassandra.thrift.KeyCount
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeyRange._Fields) - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeySlice._Fields) - Method in class org.apache.cassandra.thrift.KeySlice
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KsDef._Fields) - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MultiSliceRequest._Fields) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Mutation._Fields) - Method in class org.apache.cassandra.thrift.Mutation
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(NotFoundException._Fields) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(SchemaDisagreementException._Fields) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(SlicePredicate._Fields) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(SliceRange._Fields) - Method in class org.apache.cassandra.thrift.SliceRange
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(SuperColumn._Fields) - Method in class org.apache.cassandra.thrift.SuperColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TimedOutException._Fields) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TokenRange._Fields) - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TriggerDef._Fields) - Method in class org.apache.cassandra.thrift.TriggerDef
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(UnavailableException._Fields) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
- isSetAcknowledged_by() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
Returns true if field acknowledged_by is set (has been assigned a value) and false otherwise
- isSetAcknowledged_by_batchlog() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
Returns true if field acknowledged_by_batchlog is set (has been assigned a value) and false otherwise
- isSetAuth_request() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
Returns true if field auth_request is set (has been assigned a value) and false otherwise
- isSetAuthnx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
Returns true if field authnx is set (has been assigned a value) and false otherwise
- isSetAuthzx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
Returns true if field authzx is set (has been assigned a value) and false otherwise
- isSetBloom_filter_fp_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field bloom_filter_fp_chance is set (has been assigned a value) and false otherwise
- isSetCaching() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field caching is set (has been assigned a value) and false otherwise
- isSetCells_per_row_to_cache() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field cells_per_row_to_cache is set (has been assigned a value) and false otherwise
- isSetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
Returns true if field cf_def is set (has been assigned a value) and false otherwise
- isSetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
Returns true if field cf_def is set (has been assigned a value) and false otherwise
- isSetCf_defs() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field cf_defs is set (has been assigned a value) and false otherwise
- isSetCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Returns true if field cfName is set (has been assigned a value) and false otherwise
- isSetCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Returns true if field cfName is set (has been assigned a value) and false otherwise
- isSetCfname() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
Returns true if field cfname is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field column_family is set (has been assigned a value) and false otherwise
- isSetColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Returns true if field column_family is set (has been assigned a value) and false otherwise
- isSetColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
Returns true if field column_family is set (has been assigned a value) and false otherwise
- isSetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnParent
-
Returns true if field column_family is set (has been assigned a value) and false otherwise
- isSetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnPath
-
Returns true if field column_family is set (has been assigned a value) and false otherwise
- isSetColumn_metadata() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field column_metadata is set (has been assigned a value) and false otherwise
- isSetColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
-
Returns true if field column_name is set (has been assigned a value) and false otherwise
- isSetColumn_names() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
Returns true if field column_names is set (has been assigned a value) and false otherwise
- isSetColumn_or_supercolumn() - Method in class org.apache.cassandra.thrift.Mutation
-
Returns true if field column_or_supercolumn is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_parent() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field column_parent is set (has been assigned a value) and false otherwise
- isSetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
Returns true if field column_path is set (has been assigned a value) and false otherwise
- isSetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
Returns true if field column_path is set (has been assigned a value) and false otherwise
- isSetColumn_predicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Returns true if field column_predicate is set (has been assigned a value) and false otherwise
- isSetColumn_slices() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field column_slices is set (has been assigned a value) and false otherwise
- isSetColumn_type() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field column_type is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.cassandra.thrift.CqlRow
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.cassandra.thrift.KeySlice
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.cassandra.thrift.SuperColumn
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetComment() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field comment is set (has been assigned a value) and false otherwise
- isSetCommit_consistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field commit_consistency_level is set (has been assigned a value) and false otherwise
- isSetCompaction_strategy() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field compaction_strategy is set (has been assigned a value) and false otherwise
- isSetCompaction_strategy_options() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field compaction_strategy_options is set (has been assigned a value) and false otherwise
- isSetComparator_type() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field comparator_type is set (has been assigned a value) and false otherwise
- isSetCompression() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
Returns true if field compression is set (has been assigned a value) and false otherwise
- isSetCompression() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
Returns true if field compression is set (has been assigned a value) and false otherwise
- isSetCompression() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
Returns true if field compression is set (has been assigned a value) and false otherwise
- isSetCompression() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
Returns true if field compression is set (has been assigned a value) and false otherwise
- isSetCompression_options() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field compression_options is set (has been assigned a value) and false otherwise
- isSetConsistency() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
Returns true if field consistency is set (has been assigned a value) and false otherwise
- isSetConsistency() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
Returns true if field consistency is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetConsistency_level() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field consistency_level is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.KeyCount
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.cassandra.thrift.SliceRange
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCounter_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Returns true if field counter_column is set (has been assigned a value) and false otherwise
- isSetCounter_super_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Returns true if field counter_super_column is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCurrent_values() - Method in class org.apache.cassandra.thrift.CASResult
-
Returns true if field current_values is set (has been assigned a value) and false otherwise
- isSetDatacenter() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
Returns true if field datacenter is set (has been assigned a value) and false otherwise
- isSetDclocal_read_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field dclocal_read_repair_chance is set (has been assigned a value) and false otherwise
- isSetDefault_name_type() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
Returns true if field default_name_type is set (has been assigned a value) and false otherwise
- isSetDefault_time_to_live() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field default_time_to_live is set (has been assigned a value) and false otherwise
- isSetDefault_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field default_validation_class is set (has been assigned a value) and false otherwise
- isSetDefault_value_type() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
Returns true if field default_value_type is set (has been assigned a value) and false otherwise
- isSetDeletion() - Method in class org.apache.cassandra.thrift.Mutation
-
Returns true if field deletion is set (has been assigned a value) and false otherwise
- isSetDurable_writes() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field durable_writes is set (has been assigned a value) and false otherwise
- isSetEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field end_key is set (has been assigned a value) and false otherwise
- isSetEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Returns true if field end_token is set (has been assigned a value) and false otherwise
- isSetEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Returns true if field end_token is set (has been assigned a value) and false otherwise
- isSetEnd_token() - Method in class org.apache.cassandra.thrift.CfSplit
-
Returns true if field end_token is set (has been assigned a value) and false otherwise
- isSetEnd_token() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field end_token is set (has been assigned a value) and false otherwise
- isSetEnd_token() - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field end_token is set (has been assigned a value) and false otherwise
- isSetEndpoint_details() - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field endpoint_details is set (has been assigned a value) and false otherwise
- isSetEndpoints() - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field endpoints is set (has been assigned a value) and false otherwise
- isSetExpected() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field expected is set (has been assigned a value) and false otherwise
- isSetExpressions() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
Returns true if field expressions is set (has been assigned a value) and false otherwise
- isSetFinish() - Method in class org.apache.cassandra.thrift.ColumnSlice
-
Returns true if field finish is set (has been assigned a value) and false otherwise
- isSetFinish() - Method in class org.apache.cassandra.thrift.SliceRange
-
Returns true if field finish is set (has been assigned a value) and false otherwise
- isSetGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field gc_grace_seconds is set (has been assigned a value) and false otherwise
- isSetHost() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
Returns true if field host is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
Returns true if field index_clause is set (has been assigned a value) and false otherwise
- isSetIndex_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field index_interval is set (has been assigned a value) and false otherwise
- isSetIndex_name() - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field index_name is set (has been assigned a value) and false otherwise
- isSetIndex_options() - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field index_options is set (has been assigned a value) and false otherwise
- isSetIndex_type() - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field index_type is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
Returns true if field ire is set (has been assigned a value) and false otherwise
- isSetItemId() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
Returns true if field itemId is set (has been assigned a value) and false otherwise
- isSetItemId() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
Returns true if field itemId is set (has been assigned a value) and false otherwise
- isSetItemId() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
Returns true if field itemId is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.CqlRow
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.KeyCount
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.KeySlice
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKey_alias() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field key_alias is set (has been assigned a value) and false otherwise
- isSetKey_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field key_cache_save_period_in_seconds is set (has been assigned a value) and false otherwise
- isSetKey_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field key_cache_size is set (has been assigned a value) and false otherwise
- isSetKey_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field key_validation_class is set (has been assigned a value) and false otherwise
- isSetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Returns true if field keys is set (has been assigned a value) and false otherwise
- isSetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Returns true if field keys is set (has been assigned a value) and false otherwise
- isSetKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Returns true if field keys_per_split is set (has been assigned a value) and false otherwise
- isSetKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Returns true if field keys_per_split is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKeyspace() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field keyspace is set (has been assigned a value) and false otherwise
- isSetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
Returns true if field ks_def is set (has been assigned a value) and false otherwise
- isSetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
Returns true if field ks_def is set (has been assigned a value) and false otherwise
- isSetMax_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field max_compaction_threshold is set (has been assigned a value) and false otherwise
- isSetMax_index_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field max_index_interval is set (has been assigned a value) and false otherwise
- isSetMemtable_flush_after_mins() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field memtable_flush_after_mins is set (has been assigned a value) and false otherwise
- isSetMemtable_flush_period_in_ms() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field memtable_flush_period_in_ms is set (has been assigned a value) and false otherwise
- isSetMemtable_operations_in_millions() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field memtable_operations_in_millions is set (has been assigned a value) and false otherwise
- isSetMemtable_throughput_in_mb() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field memtable_throughput_in_mb is set (has been assigned a value) and false otherwise
- isSetMerge_shards_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field merge_shards_chance is set (has been assigned a value) and false otherwise
- isSetMin_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field min_compaction_threshold is set (has been assigned a value) and false otherwise
- isSetMin_index_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field min_index_interval is set (has been assigned a value) and false otherwise
- isSetMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
Returns true if field mutation_map is set (has been assigned a value) and false otherwise
- isSetMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
Returns true if field mutation_map is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.Column
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.CounterColumn
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.SuperColumn
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.cassandra.thrift.TriggerDef
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName_types() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
Returns true if field name_types is set (has been assigned a value) and false otherwise
- isSetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
Returns true if field nfe is set (has been assigned a value) and false otherwise
- isSetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field nfe is set (has been assigned a value) and false otherwise
- isSetNum() - Method in class org.apache.cassandra.thrift.CqlResult
-
Returns true if field num is set (has been assigned a value) and false otherwise
- isSetOp() - Method in class org.apache.cassandra.thrift.IndexExpression
-
Returns true if field op is set (has been assigned a value) and false otherwise
- isSetOptions() - Method in class org.apache.cassandra.thrift.TriggerDef
-
Returns true if field options is set (has been assigned a value) and false otherwise
- isSetPath() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Returns true if field path is set (has been assigned a value) and false otherwise
- isSetPaxos_in_progress() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
Returns true if field paxos_in_progress is set (has been assigned a value) and false otherwise
- isSetPopulate_io_cache_on_flush() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field populate_io_cache_on_flush is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetPredicate() - Method in class org.apache.cassandra.thrift.Deletion
-
Returns true if field predicate is set (has been assigned a value) and false otherwise
- isSetQuery() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
Returns true if field query is set (has been assigned a value) and false otherwise
- isSetQuery() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
Returns true if field query is set (has been assigned a value) and false otherwise
- isSetQuery() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
Returns true if field query is set (has been assigned a value) and false otherwise
- isSetQuery() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
Returns true if field query is set (has been assigned a value) and false otherwise
- isSetRack() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
Returns true if field rack is set (has been assigned a value) and false otherwise
- isSetRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Returns true if field range is set (has been assigned a value) and false otherwise
- isSetRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
Returns true if field range is set (has been assigned a value) and false otherwise
- isSetRead_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field read_repair_chance is set (has been assigned a value) and false otherwise
- isSetReplicate_on_write() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field replicate_on_write is set (has been assigned a value) and false otherwise
- isSetReplication_factor() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field replication_factor is set (has been assigned a value) and false otherwise
- isSetRequest() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
Returns true if field request is set (has been assigned a value) and false otherwise
- isSetReversed() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
Returns true if field reversed is set (has been assigned a value) and false otherwise
- isSetReversed() - Method in class org.apache.cassandra.thrift.SliceRange
-
Returns true if field reversed is set (has been assigned a value) and false otherwise
- isSetRow_cache_keys_to_save() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field row_cache_keys_to_save is set (has been assigned a value) and false otherwise
- isSetRow_cache_provider() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field row_cache_provider is set (has been assigned a value) and false otherwise
- isSetRow_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field row_cache_save_period_in_seconds is set (has been assigned a value) and false otherwise
- isSetRow_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field row_cache_size is set (has been assigned a value) and false otherwise
- isSetRow_count() - Method in class org.apache.cassandra.thrift.CfSplit
-
Returns true if field row_count is set (has been assigned a value) and false otherwise
- isSetRow_filter() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field row_filter is set (has been assigned a value) and false otherwise
- isSetRows() - Method in class org.apache.cassandra.thrift.CqlResult
-
Returns true if field rows is set (has been assigned a value) and false otherwise
- isSetRpc_endpoints() - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field rpc_endpoints is set (has been assigned a value) and false otherwise
- isSetSchema() - Method in class org.apache.cassandra.thrift.CqlResult
-
Returns true if field schema is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSde() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
Returns true if field sde is set (has been assigned a value) and false otherwise
- isSetSerial_consistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field serial_consistency_level is set (has been assigned a value) and false otherwise
- isSetSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
Returns true if field slice_range is set (has been assigned a value) and false otherwise
- isSetSpeculative_retry() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field speculative_retry is set (has been assigned a value) and false otherwise
- isSetStart() - Method in class org.apache.cassandra.thrift.ColumnSlice
-
Returns true if field start is set (has been assigned a value) and false otherwise
- isSetStart() - Method in class org.apache.cassandra.thrift.SliceRange
-
Returns true if field start is set (has been assigned a value) and false otherwise
- isSetStart_column() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
Returns true if field start_column is set (has been assigned a value) and false otherwise
- isSetStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
Returns true if field start_key is set (has been assigned a value) and false otherwise
- isSetStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field start_key is set (has been assigned a value) and false otherwise
- isSetStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Returns true if field start_token is set (has been assigned a value) and false otherwise
- isSetStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Returns true if field start_token is set (has been assigned a value) and false otherwise
- isSetStart_token() - Method in class org.apache.cassandra.thrift.CfSplit
-
Returns true if field start_token is set (has been assigned a value) and false otherwise
- isSetStart_token() - Method in class org.apache.cassandra.thrift.KeyRange
-
Returns true if field start_token is set (has been assigned a value) and false otherwise
- isSetStart_token() - Method in class org.apache.cassandra.thrift.TokenRange
-
Returns true if field start_token is set (has been assigned a value) and false otherwise
- isSetStrategy_class() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field strategy_class is set (has been assigned a value) and false otherwise
- isSetStrategy_options() - Method in class org.apache.cassandra.thrift.KsDef
-
Returns true if field strategy_options is set (has been assigned a value) and false otherwise
- isSetSubcomparator_type() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field subcomparator_type is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.CASResult
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
Returns true if field super_column is set (has been assigned a value) and false otherwise
- isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
-
Returns true if field super_column is set (has been assigned a value) and false otherwise
- isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
-
Returns true if field super_column is set (has been assigned a value) and false otherwise
- isSetSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
-
Returns true if field super_column is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
Returns true if field te is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.cassandra.thrift.Column
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.cassandra.thrift.Deletion
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTriggers() - Method in class org.apache.cassandra.thrift.CfDef
-
Returns true if field triggers is set (has been assigned a value) and false otherwise
- isSetTtl() - Method in class org.apache.cassandra.thrift.Column
-
Returns true if field ttl is set (has been assigned a value) and false otherwise
- isSetType() - Method in class org.apache.cassandra.thrift.CqlResult
-
Returns true if field type is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
Returns true if field ue is set (has been assigned a value) and false otherwise
- isSetupCompleted() - Method in class org.apache.cassandra.service.StorageService
-
- isSetUpdates() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
Returns true if field updates is set (has been assigned a value) and false otherwise
- isSetValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
-
Returns true if field validation_class is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.cassandra.thrift.Column
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.cassandra.thrift.CounterColumn
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.cassandra.thrift.IndexExpression
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue_types() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
Returns true if field value_types is set (has been assigned a value) and false otherwise
- isSetValues() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
Returns true if field values is set (has been assigned a value) and false otherwise
- isSetValues() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
Returns true if field values is set (has been assigned a value) and false otherwise
- isSetVariable_names() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
Returns true if field variable_names is set (has been assigned a value) and false otherwise
- isSetVariable_types() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
Returns true if field variable_types is set (has been assigned a value) and false otherwise
- isSetVersion() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
Returns true if field version is set (has been assigned a value) and false otherwise
- isSetWhy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
Returns true if field why is set (has been assigned a value) and false otherwise
- isSetWhy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
Returns true if field why is set (has been assigned a value) and false otherwise
- isSetWhy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
Returns true if field why is set (has been assigned a value) and false otherwise
- isShutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- isShutdown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- isShuttingDown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- isSignaled() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- isSignalled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
- isSilentShutdownState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- isSimpleSelectorFactory(int) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates Selector
s that simply return the specified column.
- isSlice() - Method in class org.apache.cassandra.cql3.Relation
-
Checks if the operator of this relation is a Slice
(GT, GTE, LTE, LT).
- isSlice() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- isSlice() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
- isSlice() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- isSlice() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
-
- isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- ISSTableScanner - Interface in org.apache.cassandra.io.sstable
-
An ISSTableScanner is an abstraction allowing multiple SSTableScanners to be
chained together under the hood.
- ISSTableSerializer<T> - Interface in org.apache.cassandra.io
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- isStart() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- isStarting() - Method in class org.apache.cassandra.service.StorageService
-
- isStarting() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns whether the storage service is starting or not
- isStarting() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isStatic() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isStatic() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- isStatic() - Method in class org.apache.cassandra.db.composites.AbstractComposite
-
- isStatic() - Method in class org.apache.cassandra.db.composites.BoundedComposite
-
- isStatic() - Method in interface org.apache.cassandra.db.composites.Composite
-
- isStatic() - Method in class org.apache.cassandra.db.composites.CompoundComposite
-
- isStaticName(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- isStillAllocating() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- isSubDirectory(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- isSubrangeRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isSuccess() - Method in class org.apache.cassandra.streaming.StreamSession
-
Return if this session completed successfully.
- isSuccess() - Method in class org.apache.cassandra.thrift.CASResult
-
- isSuccessful() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- issue() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
Issues (seals) the barrier, meaning no new operations may be issued against it, and expires the current
Group.
- isSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Checks the user's superuser status.
- isSuper(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- isSuper(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Return true if there exists a Role with the given name that also has
superuser status.
- isSuper() - Method in class org.apache.cassandra.config.CFMetaData
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
-
Check if this type of restriction is supported for by the specified index.
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
-
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
Check if this type of restriction is supported by the specified index.
- isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- isSupportedBy(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
-
- isSuspect - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- isSystem() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Some internal operations are performed on behalf of Cassandra itself, in those cases
the system user should be used where an identity is required
see CreateRoleStatement#execute() and overrides of SchemaAlteringStatement#grantPermissionsToCreator()
- isTableLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isTemporary - Variable in enum org.apache.cassandra.io.sstable.Descriptor.Type
-
- isTerminated() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- isTerminated() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- isThriftCompatible() - Method in class org.apache.cassandra.config.CFMetaData
-
Returns whether this CFMetaData can be returned to thrift.
- isThriftCompatible() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isTimeToLiveSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTraced() - Method in class org.apache.cassandra.repair.messages.RepairOption
-
- isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
-
Indicates if the current thread's execution is being traced.
- isTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- isTTLSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates TTL
selectors instances.
- isUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for reads.
- isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for writes.
- isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- isValid(InetAddress) - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
-
- isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns true if values of the other AbstractType can be read and "reasonably" interpreted by the this
AbstractType.
- isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
A version of isValueCompatibleWith() to deal with non-multicell (frozen) collections
- isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
-
- isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Needed to handle ReversedType in value-compatibility checks.
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.LongType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimeType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- isVersion2x() - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
True if runtime Hadoop version is 2.x, false otherwise.
- isWellFormed(Object[], Comparator<? extends Object>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
- isWildcard() - Method in class org.apache.cassandra.cql3.selection.Selection
-
- isWindows() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
Returns whether for a range query doing a query against merged is likely
to be faster than 2 sequential queries, one against l1 followed by one against l2.
- isWrapAround() - Method in class org.apache.cassandra.db.DataRange
-
- isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
-
Tells if the given range is a wrap around.
- isWrapAround() - Method in class org.apache.cassandra.dht.Range
-
- isWritetime - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
-
- isWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates writetime
selectors instances.
- itemId - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- itemId - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- itemId - Variable in class org.apache.cassandra.thrift.CqlPreparedResult
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterator over the columns of this map that returns only the matching @param slices.
- iterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- iterator() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator(Composite, Composite) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator(DecoratedKey, SortedSet<CellName>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator(FileDataInput, DecoratedKey, SortedSet<CellName>, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator(DecoratedKey, ColumnSlice[], boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator(FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
- iterator - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- iterator(DecoratedKey, SortedSet<CellName>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator(FileDataInput, DecoratedKey, SortedSet<CellName>, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator(DecoratedKey, ColumnSlice[], boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator(FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- iterator(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- iterator() - Method in class org.apache.cassandra.locator.PendingRangeMaps
-
- iterator() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
-
- iterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- iterator() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- iterator() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- iterator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
- 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
-
- r1 - Variable in class org.apache.cassandra.repair.SyncTask
-
- r2 - Variable in class org.apache.cassandra.repair.SyncTask
-
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rack - Variable in class org.apache.cassandra.thrift.EndpointDetails
-
- RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
-
- RackInferringSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded
in the 2nd and 3rd octets of the ip address, respectively.
- RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
-
- RandomAccessReader - Class in org.apache.cassandra.io.util
-
- RandomAccessReader(ChannelProxy, int, long, BufferType, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
-
- RandomAccessReader.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
-
Class to hold a mark to the position of the file
- RandomPartitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using MD5 hash.
- RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
-
- RandomPartitioner.BigIntegerToken - Class in org.apache.cassandra.dht
-
- Range<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
-
A representation of the range that a node is responsible for on the DHT ring.
- Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
-
- range - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
repairing range
- range - Variable in class org.apache.cassandra.repair.RepairSession
-
Range to repair
- range - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- range - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- range - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- Range.OrderedRangeContainmentChecker - Class in org.apache.cassandra.dht
-
Helper class to check if a token is contained within a given collection of ranges
- range_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RANGE_TOMBSTONE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- RANGE_XFERS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- rangeCount() - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeCovering(Composite) - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeIterator() - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeIterator(Composite, Composite) - Method in class org.apache.cassandra.db.DeletionInfo
-
- RangeKeySample - Class in org.apache.cassandra.tools.nodetool
-
- RangeKeySample() - Constructor for class org.apache.cassandra.tools.nodetool.RangeKeySample
-
- rangeLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
(Local) range slice metrics
- rangeLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
(Local) range slice metrics
- RangeNamesQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a name query.
- ranges - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- ranges - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- RANGES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
-
- rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
-
- RangeSliceCommand - Class in org.apache.cassandra.db
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a slice query.
- RangeSliceReply - Class in org.apache.cassandra.db
-
- RangeSliceReply(List<Row>) - Constructor for class org.apache.cassandra.db.RangeSliceReply
-
- RangeSliceResponseResolver - Class in org.apache.cassandra.service
-
Turns RangeSliceReply objects into row (string -> CF) maps, resolving
to the most recent ColumnFamily and setting up read repairs as necessary.
- RangeSliceResponseResolver(String, long) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
-
- RangeSliceVerbHandler - Class in org.apache.cassandra.service
-
- RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
-
- RangeStreamer - Class in org.apache.cassandra.dht
-
Assists in streaming ranges to a node.
- RangeStreamer(TokenMetadata, Collection<Token>, InetAddress, String, boolean, IEndpointSnitch, StreamStateStore) - Constructor for class org.apache.cassandra.dht.RangeStreamer
-
- RangeStreamer.ExcludeLocalNodeFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes the current node from source calculations
- RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not alive according to a
failure detector.
- RangeStreamer.ISourceFilter - Interface in org.apache.cassandra.dht
-
A filter applied to sources to stream from when constructing a fetch map.
- RangeStreamer.SingleDatacenterFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not in a specific data center.
- RangeTombstone - Class in org.apache.cassandra.db
-
- RangeTombstone(Composite, Composite, long, int) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone(Composite, Composite, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone.Serializer - Class in org.apache.cassandra.db
-
- RangeTombstone.Tracker - Class in org.apache.cassandra.db
-
Tracks opened RangeTombstones when iterating over a partition.
- RangeTombstoneList - Class in org.apache.cassandra.db
-
Data structure holding the range tombstones of a ColumnFamily.
- RangeTombstoneList(Comparator<Composite>, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
-
- RangeTombstoneList.InOrderTester - Class in org.apache.cassandra.db
-
This object allow testing whether a given column (name/timestamp) is deleted
or not by this RangeTombstoneList, assuming that the column given to this
object are passed in (comparator) sorted order.
- RangeTombstoneList.Serializer - Class in org.apache.cassandra.db
-
- rangeTombstoneSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- rangeTombstoneSerializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
-
- Raw(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier.Raw
-
- Raw() - Constructor for class org.apache.cassandra.cql3.CQL3Type.Raw
-
- Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- Raw(Selectable.Raw, ColumnIdentifier.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
-
- Raw(FunctionName, List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
-
- Raw(ColumnIdentifier.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
-
- Raw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.Raw
-
- rawAddRow(ByteBuffer...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawAddRow(List<ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawAddRow(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer given already serialized values.
- rawColumnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- rawMean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- RawSelector - Class in org.apache.cassandra.cql3.selection
-
- RawSelector(Selectable.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.RawSelector
-
- RawStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- RawStatement(CFName, SelectStatement.Parameters, List<RawSelector>, List<Relation>, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
-
- read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- read() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- read(ByteBuffer, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- read() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads a single byte from the source byte array and returns it as an
integer in the range from 0 to 255.
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads at most len
bytes from this stream and stores
them in byte array b
starting at offset
.
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- read() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(DataInput, int, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
- read(List<ReadCommand>, ConsistencyLevel, ClientState) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
- read() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.StreamReader
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CASResult
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CfDef
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CfSplit
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Column
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CqlResult
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.CqlRow
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Deletion
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- read(TProtocol) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.KeyCount
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.KeyRange
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.KeySlice
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.KsDef
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.Mutation
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.SliceRange
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.TokenRange
-
- read(TProtocol) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- read(TProtocol) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- read() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- read_repair_chance - Variable in class org.apache.cassandra.thrift.CfDef
-
- read_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- ReadableBoundary(DecoratedKey, long, long, int, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a boolean from the current position in this file.
- readBoolean() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readBoolean() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readBoundValue(ByteBuf, int) - Static method in class org.apache.cassandra.transport.CBUtil
-
- 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.io.util.NIODataInputStream
-
- readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readBytes(int) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
Does the same thing as readFully
do but without copying data (thread safe)
- 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.RandomAccessReader
-
- readBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readBytesMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytesWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadCallback<TMessage,TResolved> - Class in org.apache.cassandra.service
-
- ReadCallback(IResponseResolver<TMessage, TResolved>, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
-
Constructor when response count has to be calculated and blocked for.
- ReadCallback(IResponseResolver<TMessage, TResolved>, ConsistencyLevel, int, IReadCommand, Keyspace, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
-
- readChar() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 16-bit character from the current position in this file.
- readChar() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readChar() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readCollectionSize(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- readColumnFamily(List<ReadCommand>, ConsistencyLevel, ClientState) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- ReadCommand - Class in org.apache.cassandra.db
-
- ReadCommand(String, ByteBuffer, String, long, ReadCommand.Type) - Constructor for class org.apache.cassandra.db.ReadCommand
-
- ReadCommand.Type - Enum in org.apache.cassandra.db
-
- ReadCommands(List<ReadCommand>, int) - Constructor for class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- readConsistencyLevel(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readDouble() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit double from the current position in this file.
- readDouble() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readDouble() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readEnumValue(Class<T>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReaderState(LifecycleTransaction.ReaderState.Action, LifecycleTransaction.ReaderState.Action, SSTableReader, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
-
- readException - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- ReadFailureException - Exception in org.apache.cassandra.exceptions
-
- ReadFailureException(ConsistencyLevel, int, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
-
- readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- readFilter() - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
-
- readFilter() - Method in interface org.apache.cassandra.service.CASRequest
-
The filter to use to fetch the value to compare for the CAS.
- readFilterForCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- readFloat() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit float from the current position in this file.
- readFloat() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readFloat() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFrom(DataInput) - Static method in enum org.apache.cassandra.cql3.Operator
-
Deserializes a Operator
instance from the specified input.
- readFrom(DataInput) - Static method in class org.apache.cassandra.db.IndexExpression
-
Deserializes an IndexExpression
instance from the specified input.
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads bytes from this file into buffer
.
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Read bytes from this file into buffer
starting at offset offset
.
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readHeader(DataInput) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- readInet(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit integer from the current position in this file.
- readInt() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- readInt() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInt() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- readLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
(Local) read metrics
- readLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
(Local) read metrics
- readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a line of text form the current position in this file.
- readLine() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- 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.io.util.NIODataInputStream
-
- readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readNameAndValueList(ByteBuf, int) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readNext() - Method in class org.apache.cassandra.db.AtomDeserializer
-
Returns the next atom.
- readNext() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
-
Actually consume the next name and return it.
- readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readOrdering - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- readRawBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- ReadRepairDecision - Enum in org.apache.cassandra.config
-
- ReadRepairMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Read Repair.
- ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
-
- ReadRepairVerbHandler - Class in org.apache.cassandra.db
-
- ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
-
- readRequiredRows(Collection<ByteBuffer>, Composite, boolean, ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- ReadResponse - Class in org.apache.cassandra.db
-
- ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- ReadResponse(Row, ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- readSchemaFromSystemTables() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
- 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.io.util.NIODataInputStream
-
- readShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringList(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringToStringListMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadTimeoutException - Exception in org.apache.cassandra.exceptions
-
- ReadTimeoutException(ConsistencyLevel, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Reads the list of components from the TOC component.
- 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.io.util.NIODataInputStream
-
- 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.io.util.NIODataInputStream
-
- 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.io.util.NIODataInputStream
-
- readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- readValue(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ByteBuf, int) - Method in enum org.apache.cassandra.transport.DataType
-
- readValue(ByteBuf, int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- readValueList(ByteBuf, int) - 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
-
- reallocate(long) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- reallocate(long) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
-
- reallocate(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- realMarkAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- reBuffer() - Method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
-
- reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
Read data from file starting from current currentOffset to populate buffer.
- reBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- reBuffer() - Method in class org.apache.cassandra.io.util.ThrottledReader
-
- rebuild() - Method in class org.apache.cassandra.config.CFMetaData
-
- rebuild(String) - Method in class org.apache.cassandra.service.StorageService
-
- rebuild(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Initiate a process of streaming data for which we are responsible from other nodes.
- rebuild(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Rebuild - Class in org.apache.cassandra.tools.nodetool
-
- Rebuild() - Constructor for class org.apache.cassandra.tools.nodetool.Rebuild
-
- rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RebuildIndex - Class in org.apache.cassandra.tools.nodetool
-
- RebuildIndex() - Constructor for class org.apache.cassandra.tools.nodetool.RebuildIndex
-
- rebuildOnFailedScrub(Throwable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
CASSANDRA-5174 : For an index cfs we may be able to discard everything and just rebuild
the index when a scrub fails.
- rebuildSecondaryIndex(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- rebuildSecondaryIndex(String, String, String...) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- rebuildSecondaryIndex(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- rebuildSecondaryIndex(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
rebuild the specified indexes
- receive(MessageIn, int, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
- receive(IncomingFileMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after receiving FileMessageHeader.
- received - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
-
- received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
-
- received(SSTableWriter) - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
Process received file.
- received(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
- ReceivedMessage - Class in org.apache.cassandra.streaming.messages
-
- ReceivedMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
-
- receivers(CFMetaData) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
- receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
-
- receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of receiving summaries
- recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.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
- reclaim(Cell) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
-
- reclaimer() - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
-
- reclaimer() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
- reclaimer() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- reclaimer() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- reclaimImmediately(Cell) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
-
- reclaimImmediately(DecoratedKey) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
-
- reclaimingRatio() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.AbstractCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.BufferCounterCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- reconcile(Cell) - Method in interface org.apache.cassandra.db.Cell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- reconcile(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- reconcileCounter(Cell) - Method in class org.apache.cassandra.db.AbstractCell
-
This is temporary until we start creating Cells of the different type (buffer vs.
- ReconnectableSnitchHelper - Class in org.apache.cassandra.locator
-
Sidekick helper for snitches that want to reconnect from one IP addr for a node to another.
- ReconnectableSnitchHelper(IEndpointSnitch, String, boolean) - Constructor for class org.apache.cassandra.locator.ReconnectableSnitchHelper
-
- recordColumnDrop(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- recover() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on commit logs located in the directory specified by the config file.
- recover(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a list of commit log files.
- recover(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a single commit log.
- recover(String) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Recover a single file.
- recover(File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- recover(File, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- recursive - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- recv_add() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_atomic_batch_mutate() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_batch_mutate() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_cas() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_cluster_name() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_keyspaces() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_local_ring() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_partitioner() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_ring() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_schema_versions() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_snitch() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_splits() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_splits_ex() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_token_map() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_describe_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_execute_cql3_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_execute_cql_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_execute_prepared_cql3_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_execute_prepared_cql_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_count() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_indexed_slices() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_multi_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_paged_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_range_slices() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_get_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_insert() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_login() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_multiget_count() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_multiget_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_prepare_cql3_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_prepare_cql_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_remove() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_remove_counter() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_set_cql_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_set_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_add_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_add_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_drop_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_drop_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_update_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_system_update_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_trace_next_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recv_truncate() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- recvBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- recycle(RandomAccessReader) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- redistributeSummaries(IndexSummaryRedistribution) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on
their recent read rates.
- redistributeSummaries() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
-
- reduce(OnDiskAtomIterator) - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- reduce(OnDiskAtom) - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
-
Called once per version of a cell that we need to merge, after which getReduced() is called.
- reduce(In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
combine this object with the previous ones.
- Reducer() - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- reducer - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- Reducer() - Constructor for class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
-
- reducer - Variable in class org.apache.cassandra.utils.MergeIterator
-
- Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
-
- reduceScopeForLimitedSpace(long) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
-
Caller must acquire and release references to the sstables used here.
- ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- ref() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- ref - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- Ref<T> - Class in org.apache.cassandra.utils.concurrent
-
An object that needs ref counting does the two following:
- defines a Tidy object that will cleanup once it's gone,
(this must retain no references to the object we're tracking (only its resources and how to clean up))
Then, one of two options:
1) Construct a Ref directly pointing to it, and always use this Ref; or
2)
- implements RefCounted
- encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours
- users must ensure no references to the selfRef leak, or are retained outside of a method scope.
- Ref(T, RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.Ref
-
- ref() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
- ref() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
-
- ref(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- RefCounted<T> - Interface in org.apache.cassandra.utils.concurrent
-
An object that needs ref counting does the two following:
- defines a Tidy object that will cleanup once it's gone,
(this must retain no references to the object we're tracking (only its resources and how to clean up))
Then, one of two options:
1) Construct a Ref directly pointing to it, and always use this Ref; or
2)
- implements RefCounted
- encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours
- users must ensure no references to the selfRef leak, or are retained outside of a method scope.
- RefCounted.Tidy - Interface in org.apache.cassandra.utils.concurrent
-
- RefCountedMemory - Class in org.apache.cassandra.cache
-
- RefCountedMemory(long) - Constructor for class org.apache.cassandra.cache.RefCountedMemory
-
- reference() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Checks whether this type or any of the types this type contains references the given type.
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- Refresh - Class in org.apache.cassandra.tools.nodetool
-
- Refresh() - Constructor for class org.apache.cassandra.tools.nodetool.Refresh
-
- refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
-
- refreshSizeEstimates() - Method in class org.apache.cassandra.service.StorageService
-
- refreshSizeEstimates() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces refresh of values stored in system.size_estimates of all column families.
- refreshSizeEstimates() - Method in class org.apache.cassandra.tools.NodeProbe
-
- RefreshSizeEstimates - Class in org.apache.cassandra.tools.nodetool
-
- RefreshSizeEstimates() - Constructor for class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
-
- refs - Variable in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- Refs<T extends RefCounted<T>> - Class in org.apache.cassandra.utils.concurrent
-
A collection of managed Ref references to RefCounted objects, and the objects they are referencing.
- Refs() - Constructor for class org.apache.cassandra.utils.concurrent.Refs
-
- Refs(Map<T, Ref<T>>) - Constructor for class org.apache.cassandra.utils.concurrent.Refs
-
- RefViewFragment(List<SSTableReader>, Iterable<Memtable>, Refs<SSTableReader>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
-
Register for interesting state changes.
- register(CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
-
- register() - Static method in class org.apache.cassandra.service.GCInspector
-
- register(MigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
-
- register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
-
- register(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- register() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
Register to be signalled once allPriorOpsAreFinished() or allPriorOpsAreFinishedOrSafe() may return true
- register() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal
- register(Timer.Context) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal.
- registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Register interest for Failure Detector events.
- registerMBean(Metric, ObjectName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- RegisterMessage - Class in org.apache.cassandra.transport.messages
-
- RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
-
- registerParentRepairSession(UUID, InetAddress, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- registerReceiving(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- registerVerbHandlers(MessagingService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
-
Register a verb and the corresponding verb handler with the
Messaging Service.
- regularAndStaticColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- regularColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- regularDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- regularStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
-
- REINSERT_OVERFLOWED_TTL_OPTION_DESCRIPTION - Static variable in class org.apache.cassandra.tools.StandaloneScrubber
-
- rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- relaseAllExcept(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- Relation - Class in org.apache.cassandra.cql3
-
- Relation() - Constructor for class org.apache.cassandra.cql3.Relation
-
- relation - Variable in exception org.apache.cassandra.exceptions.UnrecognizedEntityException
-
The entity relation.
- relationType - Variable in class org.apache.cassandra.cql3.Relation
-
- relativeFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- release() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
-
- release() - Method in class org.apache.cassandra.metrics.CASClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
- release() - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
- release() - Method in class org.apache.cassandra.metrics.SEPMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
-
A convenience method for indicating when a particular request has completed
processing, and before a return to the client
- release() - Method in class org.apache.cassandra.scheduler.NoScheduler
-
- release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- release() - Method in class org.apache.cassandra.transport.Frame
-
- release() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
Must be called exactly once, when the logical operation for which this Ref was created has terminated.
- release() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release ALL of the references held by this Refs collection
- release(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- release(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release a retained Ref to all of the provided objects; if any is not held, an exception will be thrown
- release(Iterable<? extends Ref<?>>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- release(Iterable<? extends Ref<?>>, Throwable) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- releaseFileHandle() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- releaseIfHolds(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
-
Release the retained Ref to the provided object, if held, return false otherwise
- releaseReference() - Method in class org.apache.cassandra.tracing.TraceState
-
- releaseSummary() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- reload() - Method in class org.apache.cassandra.config.CFMetaData
-
Updates this object in place to match the definition in the system schema tables.
- reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- reload() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Reload an existing index following a change to its configuration,
or that of the indexed column(s).
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Drops and adds new indexes associated with the underlying CF
- reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
-
Reload the triggers which is already loaded, Invoking this will update
the class loader so new jars can be loaded.
- reloadCompactionStrategy(CFMetaData) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- reloadConfiguration(boolean) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- reloadSecondaryIndexMetadata(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Reloads the sstable metadata from disk.
- reloadTriggerClasses() - Method in class org.apache.cassandra.service.StorageProxy
-
- reloadTriggerClasses() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- reloadTriggers() - Method in class org.apache.cassandra.tools.NodeProbe
-
- ReloadTriggers - Class in org.apache.cassandra.tools.nodetool
-
- ReloadTriggers() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadTriggers
-
- relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- remaining - Variable in class org.apache.cassandra.service.pager.PagingState
-
- remainingCount() - Method in interface org.apache.cassandra.db.composites.CBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
-
Returns the number of elements that can be added to the composites.
- remainingCount() - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- RemoteSyncTask - Class in org.apache.cassandra.repair
-
RemoteSyncTask sends
SyncRequest
to remote(non-coordinator) node
to repair(stream) data with other replica.
- RemoteSyncTask(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.RemoteSyncTask
-
- REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- remove(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(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- remove(Cell) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when lazy-updating the index during compaction (CASSANDRA-2897)
- remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
remove endpoint from failure detector
- remove() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- remove(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- remove() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Remove data from the row specified by key at the granularity specified by column_path, and the given timestamp.
- remove() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.remove
-
- remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- remove(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- remove() - Method in class org.apache.cassandra.utils.btree.Cursor
-
- remove(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- remove_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
- remove_args(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
- remove_args(Cassandra.remove_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
Performs a deep copy on other.
- remove_call(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- remove_counter() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Remove a counter at the specified location.
- remove_counter() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.remove_counter
-
- remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- remove_counter_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- remove_counter_args(ByteBuffer, ColumnPath, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- remove_counter_args(Cassandra.remove_counter_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Performs a deep copy on other.
- remove_counter_call(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_counter_call
-
- remove_counter_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- remove_counter_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- remove_counter_result(Cassandra.remove_counter_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Performs a deep copy on other.
- remove_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
- remove_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
- remove_result(Cassandra.remove_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
Performs a deep copy on other.
- removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- removeCQL3Column(ColumnIdentifier) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- removed - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes deleted columns and purges gc-able tombstones.
- removeDeleted(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Purges gc-able top-level and range tombstones, returning `cf` if there are any columns or tombstones left,
null otherwise.
- removeDeletedColumnsOnly(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes only per-cell tombstones, cells that are shadowed by a row-level or range tombstone, or
columns that have been dropped from the schema (for CQL3 tables only).
- removedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
-
- removedNonlocal(UUID, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- removeEndpoint(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Remove stored tokens being used by another node
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Removes the endpoint from Gossip but retains endpoint state
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from moving endpoints
- removeFunction(FunctionName, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Delete all files and references to this index
- removeIndexedColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Removes a existing index
- removeKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace from schema
- removeNode(String) - Method in class org.apache.cassandra.service.StorageService
-
Remove a node that has died, attempting to restore the replica count.
- removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
removeToken removes token (and all data associated with
enpoint that had it) from the ring
- removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RemoveNode - Class in org.apache.cassandra.tools.nodetool
-
- RemoveNode() - Constructor for class org.apache.cassandra.tools.nodetool.RemoveNode
-
- removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
called when the repair session is done - either failed or anticompaction has completed
clears out any snapshots created by this repair
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
-
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
-
- removeProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
-
Remove progress listener from this publisher.
- removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
-
- removeRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- removeShutdownHook() - Method in class org.apache.cassandra.service.StorageService
-
In the event of forceful termination we need to remove the shutdown hook to prevent hanging (OOM for instance)
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- removeTrigger(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
This method is used to remove information about truncation time for specified column family
- removeType(UserType) - Method in class org.apache.cassandra.config.UTMetaData
-
- removeUnfinishedCompactionLeftovers(CFMetaData, Map<Integer, UUID>) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Replacing compacted sstables is atomic as far as observers of Tracker 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 Tracker's view.
- removeUnreadableSSTables(File) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
Removes every SSTable in the directory from the Tracker's view.
- removeValue(V) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removingNonlocal(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rename(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- renameColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
-
- renames(UTName, Map<ColumnIdentifier, ColumnIdentifier>) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- renameWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
-
- reorderTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- Repair - Class in org.apache.cassandra.tools.nodetool
-
- Repair() - Constructor for class org.apache.cassandra.tools.nodetool.Repair
-
- REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- repairAsync(String, Map<String, String>) - Method in class org.apache.cassandra.service.StorageService
-
- repairAsync(String, Map<String, String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- repairAsync(PrintStream, String, Map<String, String>) - Method in class org.apache.cassandra.tools.NodeProbe
-
- repairedAt - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- repairedAt - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- repairedAt - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- repairedAt - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamReader
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- repairedAt - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- RepairException - Exception in org.apache.cassandra.exceptions
-
Exception thrown during repair
- RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairException(RepairJobDesc, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairJob - Class in org.apache.cassandra.repair
-
RepairJob runs repair on given ColumnFamily.
- RepairJob(RepairSession, String, RepairParallelism, long, ListeningExecutorService) - Constructor for class org.apache.cassandra.repair.RepairJob
-
Create repair job to run on specific columnfamily
- RepairJobDesc - Class in org.apache.cassandra.repair
-
RepairJobDesc is used from various repair processes to distinguish one RepairJob to another.
- RepairJobDesc(UUID, UUID, String, String, Range<Token>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
-
- repairJobResults - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- RepairMessage - Class in org.apache.cassandra.repair.messages
-
Base class of all repair related request/response messages.
- RepairMessage(RepairMessage.Type, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
-
- RepairMessage.MessageSerializer<T extends RepairMessage> - Interface in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- RepairMessage.Type - Enum in org.apache.cassandra.repair.messages
-
- RepairMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- RepairMessageVerbHandler - Class in org.apache.cassandra.repair
-
Handles all repair related message.
- RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- RepairOption - Class in org.apache.cassandra.repair.messages
-
Repair options.
- RepairOption(RepairParallelism, boolean, boolean, boolean, int, Collection<Range<Token>>, boolean) - Constructor for class org.apache.cassandra.repair.messages.RepairOption
-
- repairOverlappingSSTables(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- RepairParallelism - Enum in org.apache.cassandra.repair
-
Specify the degree of parallelism when calculating the merkle trees in a repair job.
- RepairResult - Class in org.apache.cassandra.repair
-
RepairJob's result
- RepairResult(RepairJobDesc, List<SyncStat>) - Constructor for class org.apache.cassandra.repair.RepairResult
-
- repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- repairResults - Variable in class org.apache.cassandra.service.RowDataResolver
-
- RepairRunnable - Class in org.apache.cassandra.repair
-
- RepairRunnable(StorageService, int, RepairOption, String) - Constructor for class org.apache.cassandra.repair.RepairRunnable
-
- RepairRunner - Class in org.apache.cassandra.tools
-
- RepairRunner(PrintStream, StorageServiceMBean, String, Map<String, String>) - Constructor for class org.apache.cassandra.tools.RepairRunner
-
- RepairSession - Class in org.apache.cassandra.repair
-
Coordinates the (active) repair of a token range.
- RepairSession(UUID, UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, long, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
-
Create new repair session.
- RepairSessionResult - Class in org.apache.cassandra.repair
-
Repair session result
- RepairSessionResult(UUID, String, Range<Token>, Collection<RepairResult>) - Constructor for class org.apache.cassandra.repair.RepairSessionResult
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- replace(K, V, V) - Method in interface org.apache.cassandra.cache.ICache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- replace(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- replaceColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- 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.compaction.AbstractCompactionStrategy
-
Handle a flushed memtable.
- replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- replaceKiller(JVMStabilityInspector.Killer) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- replacementQuarantine(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Quarantine endpoint specifically for replacement purposes.
- replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- ReplayFilter(Iterable<SSTableReader>, ReplayPosition) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
-
- ReplayPosition - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
-
- ReplayPosition.ReplayFilter - Class in org.apache.cassandra.db.commitlog
-
A filter of known safe-to-discard commit log replay positions, based on
the range covered by on disk sstables and those prior to the most recent truncation record
- ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
-
- ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- replicasMissingMostRecentCommit(CFMetaData, long) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- replicate_on_write - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- replication_factor - Variable in class org.apache.cassandra.thrift.KsDef
-
- REPLICATION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.statements.KSPropDefs
-
- ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
-
- ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
-
- replies - Variable in class org.apache.cassandra.service.AbstractRowResolver
-
- report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by the receiver of the heartbeat.
- ReporterWrapper - Class in org.apache.cassandra.hadoop
-
A reporter that works with both mapred and mapreduce APIs.
- ReporterWrapper(Reporter) - Constructor for class org.apache.cassandra.hadoop.ReporterWrapper
-
- reportManualSeverity(double) - Method in class org.apache.cassandra.service.StorageService
-
- reportSeverity(double) - Method in class org.apache.cassandra.service.StorageService
-
Increment about the known Compaction severity of the events in this node
- request - Variable in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
-
- request_scheduler - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_id - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_options - Variable in class org.apache.cassandra.config.Config
-
- request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RequestExecutionException - Exception in org.apache.cassandra.exceptions
-
- RequestExecutionException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- RequestExecutionException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- requestExtraSync() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
Sync immediately, but don't block for the sync to cmplete
- requestExtraSync() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Preempts the CLExecutor, telling to to sync immediately
- RequestFailureException - Exception in org.apache.cassandra.exceptions
-
- RequestFailureException(ExceptionCode, ConsistencyLevel, int, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestFailureException
-
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- requestNames() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
Return only the column names requested by the user, excluding those added for post-query re-orderings,
see definition of names and columnCount.
- requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in keyspace
and ranges
from specific node.
- requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in columnFamilies
under keyspace
and ranges
from specific node.
- requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total number of cache requests
- requests - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
-
Total number of requests
- requests - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Streaming requests
- requests - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- requests - Variable in class org.apache.cassandra.streaming.StreamSession
-
- RequestSchedulerOptions - Class in org.apache.cassandra.config
-
- RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
-
- RequestThreadPoolExecutor - Class in org.apache.cassandra.transport
-
- RequestThreadPoolExecutor() - Constructor for class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- RequestTimeoutException - Exception in org.apache.cassandra.exceptions
-
- RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- RequestValidationException - Exception in org.apache.cassandra.exceptions
-
- RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidations - Class in org.apache.cassandra.cql3.statements
-
Utility methods use to perform request validation.
- require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Whether or not the authenticator requires explicit login.
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- 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_ALLOW_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Operation
-
- requiresRead() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- requiresScanningAllRanges() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- requiresScanningAllRanges(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
Returns
true
if the specified list of
IndexExpression
s require a full scan of all the nodes.
- rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
-
- rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
-
Retry all failed deletions.
- rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
Retry all deletions that failed the first time around (presumably b/c the sstable was still mmap'd.)
Useful because there are times when we know GC has been invoked; also exposed as an mbean.
- reserializeToV3(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- reset() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Reset this aggregate.
- reset() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Reset the internal state of this Selector
.
- reset() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
-
- reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- reset(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
(Re)initializes the tracker, purging all references.
- reset(FileMark) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Resets this stream to the last marked location.
- reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- reset() - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
reconnect to @param remoteEP (after the current message backlog is exhausted).
- reset(Object[], boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
-
Reset this cursor for the provided tree, to iterate over its entire range
- reset(Object[], Comparator<K>, K, K, boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
-
Reset this cursor for the provided tree, to iterate between the provided start and end
- reset(Object[], Comparator<K>, K, boolean, K, boolean, boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
-
Reset this cursor for the provided tree, to iterate between the provided start and end
- reset(long) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
reset counter to @param count
- reset() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- reset() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- reset() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- reset() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Reset the writer so that the next chunk offset written will be the
one of chunkIndex
.
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
-
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Drops all buffered data that's past the limits of our new file mark + buffer capacity, or syncs and truncates
the underlying file to the marked position
- resetAvailableRanges() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetCollection(String) - Method in class org.apache.cassandra.db.CFRowAdder
-
- resetConfiguration() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetForTests() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
-
- resetLocalSchema() - Static method in class org.apache.cassandra.service.MigrationManager
-
Clear all locally stored schema information and reset schema to initial state.
- resetLocalSchema() - Method in class org.apache.cassandra.service.StorageService
-
- resetLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- resetLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
-
- ResetLocalSchema - Class in org.apache.cassandra.tools.nodetool
-
- ResetLocalSchema() - Constructor for class org.apache.cassandra.tools.nodetool.ResetLocalSchema
-
- resetTidying() - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- resetUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- resetWarnings() - Method in class org.apache.cassandra.service.ClientWarn
-
- resolve() - Method in 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
-
- resolveIp - Variable in class org.apache.cassandra.tools.nodetool.HostStat
-
- 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 - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- resource - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- RESOURCE_ROLE_INDEX - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- Resources - Class in org.apache.cassandra.auth
-
- Resources() - Constructor for class org.apache.cassandra.auth.Resources
-
- resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ResourceWatcher - Class in org.apache.cassandra.utils
-
- ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
-
- ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
-
- respectTombstoneThresholds() - Method in class org.apache.cassandra.db.columniterator.IdentityQueryFilter
-
- respectTombstoneThresholds() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- response(MessageIn<T>) - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
null message means "response from local write"
- response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- response(MessageIn<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- response(MessageIn<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- response(MessageIn<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<T>) - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
-
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
-
- 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
-
- restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
FOR TESTING ONLY
- restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- RestorableMeter - Class in org.apache.cassandra.metrics
-
A meter metric which measures mean throughput as well as fifteen-minute and two-hour
exponentially-weighted moving average throughputs.
- RestorableMeter() - Constructor for class org.apache.cassandra.metrics.RestorableMeter
-
Creates a new, uninitialized RestorableMeter.
- RestorableMeter(double, double) - Constructor for class org.apache.cassandra.metrics.RestorableMeter
-
Restores a RestorableMeter from the last seen 15m and 2h rates.
- restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- Restriction - Interface in org.apache.cassandra.cql3.restrictions
-
A restriction/clause on a column.
- result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- resultify(String, List<Row>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- ResultMessage - Class in org.apache.cassandra.transport.messages
-
- ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
-
- ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Void - Class in org.apache.cassandra.transport.messages
-
- ResultMetadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
Describes the results of executing this prepared statement
- ResultSet - Class in org.apache.cassandra.cql3
-
- ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet(ResultSet.ResultMetadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet.Codec - Class in org.apache.cassandra.cql3
-
- ResultSet.Flag - Enum in org.apache.cassandra.cql3
-
- ResultSet.PreparedMetadata - Class in org.apache.cassandra.cql3
-
The metadata for the query parameters in a prepared statement.
- ResultSet.ResultMetadata - Class in org.apache.cassandra.cql3
-
The metadata for the results of executing a query or prepared statement.
- resultSetBuilder(long, boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
-
- resume() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
For internal, temporary suspension of background compactions so that we can do exceptional
things like truncate or major compaction
- resumeBootstrap() - Method in class org.apache.cassandra.service.StorageService
-
- resumeBootstrap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Resume bootstrap streaming when there is failed data streaming.
- resumeBootstrap(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
-
- resumeFlushing() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- ResumeHandoff - Class in org.apache.cassandra.tools.nodetool
-
- ResumeHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.ResumeHandoff
-
- resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
-
- retain() - Method in class org.apache.cassandra.transport.Frame
-
- retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
-
- RetriedSliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- retrieveTemporaryBuffer(int) - Static method in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- RetryMessage - Class in org.apache.cassandra.streaming.messages
-
- RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- returnCode - Variable in exception org.apache.cassandra.exceptions.StartupException
-
- returnDataType - Variable in class org.apache.cassandra.cql3.functions.UDFunction
-
- returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- reverse() - Method in enum org.apache.cassandra.cql3.Operator
-
Returns the reverse operator if this one.
- reverse() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- reverse() - Method in class org.apache.cassandra.cql3.ResultSet
-
- reverse() - Method in enum org.apache.cassandra.cql3.statements.Bound
-
- reverse() - Method in class org.apache.cassandra.utils.AsymmetricOrdering
-
- reverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- reverseComparator() - Method in interface org.apache.cassandra.db.composites.CType
-
- reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- reversed - Variable in class org.apache.cassandra.thrift.MultiSliceRequest
-
- reversed - Variable in class org.apache.cassandra.thrift.SliceRange
-
- ReversedType<T> - Class in org.apache.cassandra.db.marshal
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
- reverseIterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- reverseMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Revokes a set of permissions on a resource from a user.
- revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAllFrom(RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Called before deleting a role with DROP ROLE statement (or the alias provided for compatibility,
DROP USER) so that a new role with the same name wouldn't inherit permissions of the deleted one in the future.
- revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAllOn(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called after a resource is removed (i.e.
- RevokePermissionsStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokePermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
-
- revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during the execution of a REVOKE ROLE query.
- RevokeRoleStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokeRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokeRoleStatement
-
- right - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- right - Variable in class org.apache.cassandra.utils.Pair
-
- rightBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- Ring - Class in org.apache.cassandra.tools.nodetool
-
- Ring() - Constructor for class org.apache.cassandra.tools.nodetool.Ring
-
- RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
-
- RingCache - Class in org.apache.cassandra.client
-
A class for caching the ring map at the client.
- RingCache(Configuration) - Constructor for class org.apache.cassandra.client.RingCache
-
- ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
iterator over the Tokens in the given ring, starting with the token for the node owning start
(which does not have to be a Token in the ring)
- RingPosition<C extends RingPosition<C>> - Interface in org.apache.cassandra.dht
-
Interface representing a position on the ring.
- RMIServerSocketFactoryImpl - Class in org.apache.cassandra.utils
-
- RMIServerSocketFactoryImpl() - Constructor for class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
-
- role(String) - Static method in class org.apache.cassandra.auth.RoleResource
-
Creates a RoleResource representing an individual Role.
- role - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- role_manager - Variable in class org.apache.cassandra.config.Config
-
- ROLE_MEMBERS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- ROLE_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- RoleManagementStatement - Class in org.apache.cassandra.cql3.statements
-
- RoleManagementStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- RoleName - Class in org.apache.cassandra.cql3
-
- RoleName() - Constructor for class org.apache.cassandra.cql3.RoleName
-
- RoleOptions - Class in org.apache.cassandra.auth
-
- RoleOptions() - Constructor for class org.apache.cassandra.auth.RoleOptions
-
- RoleResource - Class in org.apache.cassandra.auth
-
IResource implementation representing database roles.
- ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- Roles - Class in org.apache.cassandra.auth
-
- Roles() - Constructor for class org.apache.cassandra.auth.Roles
-
- roles_cache_max_entries - Variable in class org.apache.cassandra.config.Config
-
- roles_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
-
- roles_validity_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RolesCache - Class in org.apache.cassandra.auth
-
- RolesCache(IRoleManager) - Constructor for class org.apache.cassandra.auth.RolesCache
-
- RolesCacheMBean - Interface in org.apache.cassandra.auth
-
- root() - Static method in class org.apache.cassandra.auth.DataResource
-
- root() - Static method in class org.apache.cassandra.auth.FunctionResource
-
- ROOT - Static variable in class org.apache.cassandra.auth.Resources
-
Deprecated.
- root() - Static method in class org.apache.cassandra.auth.RoleResource
-
- rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- RoundRobinScheduler - Class in org.apache.cassandra.scheduler
-
A very basic Round Robin implementation of the RequestScheduler.
- RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- Row(Map<String, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- Row(List<ColumnSpecification>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- row() - Method in class org.apache.cassandra.db.ReadResponse
-
- Row - Class in org.apache.cassandra.db
-
- Row(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row.RowSerializer - Class in org.apache.cassandra.db
-
- row_cache_class_name - Variable in class org.apache.cassandra.config.Config
-
- row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- row_cache_keys_to_save - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- row_cache_provider - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- row_cache_save_period - Variable in class org.apache.cassandra.config.Config
-
- row_cache_save_period_in_seconds - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- row_cache_size - Variable in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- row_count - Variable in class org.apache.cassandra.thrift.CfSplit
-
- row_filter - Variable in class org.apache.cassandra.thrift.KeyRange
-
- rowCache - Variable in class org.apache.cassandra.cache.CachingOptions
-
- RowCache(CachingOptions.RowCache.Type) - Constructor for class org.apache.cassandra.cache.CachingOptions.RowCache
-
- RowCache(CachingOptions.RowCache.Type, int) - Constructor for class org.apache.cassandra.cache.CachingOptions.RowCache
-
- rowCache - Variable in class org.apache.cassandra.service.CacheService
-
- rowCacheHit - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Number of row cache hits
- rowCacheHitOutOfRange - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Row cache hits, but result out of range
- RowCacheKey - Class in org.apache.cassandra.cache
-
- RowCacheKey(Pair<String, String>, byte[]) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(Pair<String, String>, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(Pair<String, String>, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- rowCacheMiss - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Number of row cache misses
- RowCacheSentinel - Class in org.apache.cassandra.cache
-
A sentinel object for row caches.
- RowCacheSentinel() - Constructor for class org.apache.cassandra.cache.RowCacheSentinel
-
- RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- rowCount() - Method in class org.apache.cassandra.utils.MerkleTree
-
- RowDataResolver - Class in org.apache.cassandra.service
-
- RowDataResolver(String, ByteBuffer, IDiskAtomFilter, long, int) - Constructor for class org.apache.cassandra.service.RowDataResolver
-
- RowDigestResolver - Class in org.apache.cassandra.service
-
- RowDigestResolver(String, ByteBuffer, int) - Constructor for class org.apache.cassandra.service.RowDigestResolver
-
- rowFilter - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
-
- RowIndexEntry<T> - Class in org.apache.cassandra.db
-
- RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
-
- RowIndexEntry.IndexSerializer<T> - Interface in org.apache.cassandra.db
-
- RowIndexEntry.Serializer - Class in org.apache.cassandra.db
-
- rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- RowIteratorFactory - Class in org.apache.cassandra.db
-
- RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
-
- rowMarker(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- rowMarker(Composite) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Creates a row marker for the CQL3 having the provided clustering prefix.
- rowMarker(Composite) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- rowMarkerId - Static variable in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- RowPosition - Interface in org.apache.cassandra.db
-
- RowPosition.ForKey - Class in org.apache.cassandra.db
-
- RowPosition.Kind - Enum in org.apache.cassandra.db
-
- RowPosition.RowPositionSerializer - Class in org.apache.cassandra.db
-
- RowPositionSerializer() - Constructor for class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- rowPositionSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
-
- 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.compaction.LazilyCompactedRow
-
- rows - Variable in class org.apache.cassandra.db.RangeSliceReply
-
- rows - Variable in class org.apache.cassandra.thrift.CqlResult
-
- Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- ROWS_ONLY - Static variable in class org.apache.cassandra.cache.CachingOptions
-
- RowSerializer() - Constructor for class org.apache.cassandra.db.Row.RowSerializer
-
- rowsOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowsOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowsToCache - Variable in class org.apache.cassandra.cache.CachingOptions.RowCache
-
- rpc_address - Variable in class org.apache.cassandra.config.Config
-
- rpc_endpoints - Variable in class org.apache.cassandra.thrift.TokenRange
-
- rpc_interface - Variable in class org.apache.cassandra.config.Config
-
- rpc_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
-
- rpc_keepalive - Variable in class org.apache.cassandra.config.Config
-
- rpc_listen_backlog - Variable in class org.apache.cassandra.config.Config
-
- rpc_max_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_min_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_port - Variable in class org.apache.cassandra.config.Config
-
- rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_server_type - Variable in class org.apache.cassandra.config.Config
-
- rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rpcPort - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- rpcPort - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- rpcReady(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- run() - Method in class org.apache.cassandra.db.ColumnFamilyStore.FlushLargestColumnFamily
-
- run() - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
-
- run() - Method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
-
- run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- run() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
A new connection will either stream or message for its entire lifetime: because streaming
bypasses the InputStream implementations to use sendFile, we cannot begin buffering until
we've determined the type of the connection.
- run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
-
- run() - Method in class org.apache.cassandra.net.MessagingService.SocketThread
-
- run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- run() - Method in class org.apache.cassandra.repair.AnticompactionTask
-
- run() - Method in class org.apache.cassandra.repair.RepairJob
-
Runs repair job.
- run() - Method in class org.apache.cassandra.repair.SnapshotTask
-
- run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
- run() - Method in class org.apache.cassandra.repair.SyncTask
-
Compares trees, and triggers repairs for any ranges that mismatch.
- run() - Method in class org.apache.cassandra.repair.ValidationTask
-
Send ValidationRequest to replica
- run() - Method in class org.apache.cassandra.repair.Validator
-
Called after the validation lifecycle to respond with the now valid tree.
- run() - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
-
- run() - Method in class org.apache.cassandra.tools.RepairRunner
-
- run() - Method in class org.apache.cassandra.transport.Client
-
- run() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor.BackgroundActivityReporter
-
- run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- run() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runIndexSummaryRedistribution(IndexSummaryRedistribution) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- runMayThrow() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
For internal use and testing only.
- runMayThrow() - Method in class org.apache.cassandra.repair.RepairRunnable
-
- runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runOnClose(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- runWithCompactionsDisabled(Callable<V>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SafeMemory - Class in org.apache.cassandra.io.util
-
- SafeMemory(long) - Constructor for class org.apache.cassandra.io.util.SafeMemory
-
- SafeMemoryWriter - Class in org.apache.cassandra.io.util
-
- SafeMemoryWriter(long) - Constructor for class org.apache.cassandra.io.util.SafeMemoryWriter
-
- sampleKeyRange() - Method in class org.apache.cassandra.service.StorageService
-
#Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
- sampleKeyRange() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
- sampleKeyRange() - Method in class org.apache.cassandra.tools.NodeProbe
-
- sampleLatencyNanos - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- SamplerResult(List<Counter<S>>, long) - Constructor for class org.apache.cassandra.utils.TopKSampler.SamplerResult
-
- samplers - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- satisfies(int, Operator) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- saveCaches() - Method in class org.apache.cassandra.service.CacheService
-
- saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
save row and key caches
- saved_caches_directory - Variable in class org.apache.cassandra.config.Config
-
- savePaxosCommit(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosPromise(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- saveSummary(SegmentedFile.Builder, SegmentedFile.Builder) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Save index summary to Summary.db file.
- saveSummary(Descriptor, DecoratedKey, DecoratedKey, SegmentedFile.Builder, SegmentedFile.Builder, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Save index summary to Summary.db file.
- saveSystemKeyspaceSchema() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
-
add entries to system.schema_* for the hardcoded system definitions
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- ScalarFunction - Interface in org.apache.cassandra.cql3.functions
-
Determines a single output value based on a single input value.
- ScannerList(List<ISSTableScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- ScheduledExecutors - Class in org.apache.cassandra.concurrent
-
Centralized location for shared executors
- ScheduledExecutors() - Constructor for class org.apache.cassandra.concurrent.ScheduledExecutors
-
- scheduledTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
-
This pool is used for periodic short (sub-second) tasks.
- scheduleHintDelivery(InetAddress, boolean) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
force hint delivery to an endpoint
- scheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowDataResolver
-
For each row version, compare with resolved (the superset of all row versions);
if it is missing anything, send a mutation to the endpoint it come from.
- scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- scheduleSchemaPull(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
-
- scheduleTimeout(int, long, TimeUnit) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Schedule timeout task to release reference for file sent.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- Schema - Class in org.apache.cassandra.config
-
- Schema() - Constructor for class org.apache.cassandra.config.Schema
-
Initialize empty schema object and load the hardcoded system tables
- schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- schema - Variable in class org.apache.cassandra.thrift.CqlResult
-
- 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
-
- SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String, List<String>) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
-
- SchemaChange(Event.SchemaChange) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- SchemaCheckVerbHandler - Class in org.apache.cassandra.db
-
- SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- SchemaDisagreementException - Exception in org.apache.cassandra.thrift
-
NOTE: This up outdated exception left for backward compatibility reasons,
no actual schema agreement validation is done starting from Cassandra 1.2
schemas are not in agreement across all nodes
- SchemaDisagreementException() - Constructor for exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- SchemaDisagreementException(SchemaDisagreementException) - Constructor for exception org.apache.cassandra.thrift.SchemaDisagreementException
-
Performs a deep copy on other.
- SchemaDisagreementException._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- scName(Composite) - Static method in class org.apache.cassandra.db.SuperColumns
-
- scNameType(CellNameType) - Static method in class org.apache.cassandra.db.SuperColumns
-
- ScriptBasedUDF - Class in org.apache.cassandra.cql3.functions
-
- scrub(boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- scrub(boolean, boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- scrub(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- scrub(boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- scrub(PrintStream, boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Scrub - Class in org.apache.cassandra.tools.nodetool
-
- Scrub() - Constructor for class org.apache.cassandra.tools.nodetool.Scrub
-
- Scrubber - Class in org.apache.cassandra.db.compaction
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, OutputHandler, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber.NegativeLocalDeletionInfoMetrics - Class in org.apache.cassandra.db.compaction
-
- Scrubber.ScrubResult - Class in org.apache.cassandra.db.compaction
-
- scrubDataDirectories(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
and compacted sstables.
- ScrubResult(Scrubber) - Constructor for class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
-
- scrubWithResult() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- sde - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
-
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Performs a search across a number of column indexes
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- search(Composite) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
-
- search(C) - Method in class org.apache.cassandra.utils.IntervalTree
-
- searchDeletionTime(Composite) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns the DeletionTime for the tombstone overlapping name
(there can't be more than one),
or null if name
is not covered by any tombstone.
- searcher - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- searchIterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- searchIterator() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- searchIterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- SearchIterator<K,V> - Interface in org.apache.cassandra.utils
-
- 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
-
- seek(long) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
-
- 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.MemoryInputStream
-
- seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- seek(long) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
-
- segment - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- SegmentedFile - Class in org.apache.cassandra.io.util
-
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent
FileDataInput.
- SegmentedFile(SegmentedFile.Cleanup, ChannelProxy, long, long) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
-
- SegmentedFile(SegmentedFile) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
-
- SegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
Collects potential segmentation points in an underlying file, and builds a SegmentedFile to represent it.
- SegmentedFile.Cleanup - Class in org.apache.cassandra.io.util
-
- select(Function<View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- selectable - Variable in class org.apache.cassandra.cql3.selection.RawSelector
-
- Selectable - Class in org.apache.cassandra.cql3.selection
-
- Selectable() - Constructor for class org.apache.cassandra.cql3.selection.Selectable
-
- Selectable.Raw - Interface in org.apache.cassandra.cql3.selection
-
- Selectable.WithFieldSelection - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFieldSelection.Raw - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFunction - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WithFunction.Raw - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.selection
-
- Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.selection
-
- selectAndReference(Function<View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
-
- selectFullRow - Variable in class org.apache.cassandra.db.DataRange
-
- Selection - Class in org.apache.cassandra.cql3.selection
-
- Selection(CFMetaData, List<ColumnDefinition>, SelectionColumnMapping, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selection
-
- Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.selection
-
- SelectionColumnMapping - Class in org.apache.cassandra.cql3.selection
-
Separately maintains the ColumnSpecifications and their mappings to underlying
columns as we may receive null mappings.
- SelectionColumns - Interface in org.apache.cassandra.cql3.selection
-
Represents a mapping between the actual columns used to satisfy a Selection
and the column definitions included in the resultset metadata for the query.
- Selector - Class in org.apache.cassandra.cql3.selection
-
A Selector
is used to convert the data returned by the storage engine into the data requested by the
user.
- Selector() - Constructor for class org.apache.cassandra.cql3.selection.Selector
-
- Selector.Factory - Class in org.apache.cassandra.cql3.selection
-
A factory for Selector
instances.
- selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
-
- SelectStatement - Class in org.apache.cassandra.cql3.statements
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(CFMetaData, int, SelectStatement.Parameters, Selection, StatementRestrictions, boolean, Comparator<List<ByteBuffer>>, Term) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
-
- SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- selfRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- selfRef() - Method in interface org.apache.cassandra.utils.concurrent.SelfRefCounted
-
- SelfRefCounted<T extends SelfRefCounted<T>> - Interface in org.apache.cassandra.utils.concurrent
-
- selfRefs(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
- send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- send_add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_atomic_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_cluster_name() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_keyspaces() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_local_ring(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_partitioner() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_ring(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_schema_versions() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_snitch() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_splits_ex(String, String, String, int) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_token_map() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_describe_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_execute_cql3_query(ByteBuffer, Compression, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_execute_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_execute_prepared_cql3_query(int, List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_execute_prepared_cql_query(int, List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_multi_slice(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_prepare_cql3_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_prepare_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_set_cql_version(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_set_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_trace_next_query() - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- send_truncate(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- 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.
- sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendOneWay(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- sendReply(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
Send a non-mutation message to a given endpoint.
- sendRR(MessageOut<?>, InetAddress, AbstractWriteResponseHandler<?>, boolean) - Method in class org.apache.cassandra.net.MessagingService
-
Send a mutation message or a Paxos Commit to a given endpoint.
- sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRRWithFailure(MessageOut, InetAddress, IAsyncCallbackWithFailure) - Method in class org.apache.cassandra.net.MessagingService
-
- sendToHintedEndpoints(Mutation, Iterable<InetAddress>, AbstractWriteResponseHandler<IMutation>, String) - 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.
- separator - Static variable in class org.apache.cassandra.io.sstable.Component
-
- SEPExecutor - Class in org.apache.cassandra.concurrent
-
- SEPMetrics - Class in org.apache.cassandra.metrics
-
- SEPMetrics(SEPExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.SEPMetrics
-
Create metrics for the given LowSignalExecutor.
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- SequentialWriter - Class in org.apache.cassandra.io.util
-
Adds buffering, mark, and fsyncing to OutputStream.
- SequentialWriter(File, int, BufferType) - 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.TransactionalProxy - Class in org.apache.cassandra.io.util
-
- serial_consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- serializationFlags() - Method in class org.apache.cassandra.db.AbstractCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.BufferCounterCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- serializationFlags() - Method in interface org.apache.cassandra.db.Cell
-
- serializationFlags() - Method in class org.apache.cassandra.db.NativeCounterCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- serializationFlags() - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- serialize(K, DataOutputPlus, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- serialize(ColumnFamily, DataOutputPlus, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serialize(Cell, DataOutputPlus) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serialize(ReplayPosition, DataOutputPlus) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serialize(CounterMutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
-
- serialize(DeletionInfo, DataOutputPlus, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serialize(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- serialize(ColumnSlice, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serialize(IDiskAtomFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serialize(NamesQueryFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serialize(SliceQueryFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serialize(Mutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
-
- serialize(RangeTombstoneList, DataOutputPlus, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serialize(Row, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serialize(RowIndexEntry<T>, DataOutputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- serialize(RowIndexEntry<IndexHelper.IndexInfo>, DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serialize(RowPosition, DataOutputPlus, int) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serialize(TruncateResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serialize(WriteResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serialize(AbstractBounds<T>, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serialize(String, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(Token, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serialize(EchoMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISerializer
-
Serialize the specified type into the specified DataOutput instance.
- serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(IndexHelper.IndexInfo, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
-
- serialize(IndexSummary, DataOutputPlus, boolean) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- serialize(CompactionMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serialize(T, Version, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Serialize metadata component to given output.
- serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Serialize given metadata components
- serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
-
Deprecated.
Legacy serialization is only used for SSTable level reset.
- serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- serialize(StatsMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serialize(ValidationMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.net.MessageOut
-
- serialize(AnticompactionRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- serialize(CleanupMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- serialize(PrepareMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
-
- serialize(RepairMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serialize(SnapshotMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- serialize(SyncRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serialize(ValidationRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serialize(NodePair, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- serialize(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- serialize(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- serialize(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- serialize(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- serialize(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- serialize(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- serialize(CounterCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
-
- serialize(KeyCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- serialize(RowCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- serialize(Collection<Mutation>, DataOutputPlus, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serialize() - Method in class org.apache.cassandra.service.pager.PagingState
-
- serialize(Commit, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serialize(PrepareResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serialize(DataOutputStreamPlus, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- serialize(StreamMessage, DataOutputStreamPlus, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- serialize(V, DataOutputStreamPlus, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- serialize(StreamRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serialize(StreamSummary, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serialize(Tracing.TraceType) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
- serialize(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event
-
- serialize(EnumSet<Frame.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
- serialize(Boolean, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serialize(EstimatedHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- serialize(IFilter, DataOutputPlus) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- serialize(IntervalTree<C, D, I>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serialize(MerkleTree, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serialize(DataOutput) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serialize(StreamingHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serialize(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
-
- serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- serializeCfId(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.AbstractCell
-
- serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.BufferCounterCell
-
- serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- serializedSize(CellNameType, TypeSizes) - Method in interface org.apache.cassandra.db.Cell
-
- serializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(ColumnFamily, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(Cell, TypeSizes) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serializedSize(ReplayPosition, TypeSizes) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serializedSize(CounterMutation, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
-
- serializedSize(DeletionInfo, TypeSizes, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(DeletionInfo, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(DeletionTime, TypeSizes) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- serializedSize(ColumnSlice, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serializedSize(IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serializedSize(NamesQueryFilter, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serializedSize(SliceQueryFilter, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serializedSize(Mutation, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
-
- serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- serializedSize(RangeTombstoneList, TypeSizes, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(RangeTombstoneList, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(Row, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serializedSize(RowIndexEntry<T>) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
-
- serializedSize(RowIndexEntry<IndexHelper.IndexInfo>) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializedSize(RowPosition, int) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serializedSize(WriteResponse, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serializedSize(AbstractBounds<T>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(Token, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serializedSize(EchoMessage, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serializedSize(T, TypeSizes) - Method in interface org.apache.cassandra.io.ISerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(IndexHelper.IndexInfo, TypeSizes) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
-
- serializedSize(CompactionMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serializedSize(T, Version) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Calculate and return serialized size.
- serializedSize(StatsMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serializedSize(ValidationMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
-
- serializedSize(AnticompactionRequest, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
-
- serializedSize(CleanupMessage, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
-
- serializedSize(PrepareMessage, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
-
- serializedSize(RepairMessage, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serializedSize(SnapshotMessage, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- serializedSize(SyncRequest, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serializedSize(ValidationRequest, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serializedSize(NodePair, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serializedSize(Collection<Mutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serializedSize(Commit, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serializedSize(StreamRequest, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serializedSize(StreamSummary, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serializedSize(int) - Method in class org.apache.cassandra.transport.Event
-
- serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- serializedSize() - Method in class org.apache.cassandra.utils.BloomFilter
-
- 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(TypeSizes) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serializedSize(StreamingHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializedSizeForSSTable(OnDiskAtom) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- serializedSizeForSSTable(OnDiskAtom) - Method in interface org.apache.cassandra.db.OnDiskAtom.SerializerForWriting
-
- serializedSizeForSSTable(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- serializedValue - Variable in enum org.apache.cassandra.db.ReadCommand.Type
-
- serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.MapType
-
- serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- serializedValueSize(Object, int) - Method in enum org.apache.cassandra.transport.DataType
-
- serializedValueSize(Object, int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.SchemaChange
-
- serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event
-
- serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.StatusChange
-
- serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.TopologyChange
-
- serializeForNativeProtocol(ColumnDefinition, List<Cell>, int) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- serializeForSSTable(ColumnFamily, DataOutputPlus) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeForSSTable(OnDiskAtom, DataOutputPlus) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- serializeForSSTable(OnDiskAtom, DataOutputPlus) - Method in interface org.apache.cassandra.db.OnDiskAtom.SerializerForWriting
-
- serializeForSSTable(RangeTombstone, DataOutputPlus) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- serializeForSSTable(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Serialize the specified type into the specified DataOutputStream
instance in the format suited for SSTables.
- serializer - Static variable in class org.apache.cassandra.db.ColumnFamily
-
- serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- serializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- serializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- serializer - Static variable in class org.apache.cassandra.db.CounterMutation
-
- Serializer(CType) - Constructor for class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.DeletionTime
-
- Serializer() - Constructor for class org.apache.cassandra.db.DeletionTime.Serializer
-
- Serializer(CType) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- Serializer(CType) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serializer - Variable in class org.apache.cassandra.db.marshal.ListType
-
- serializer - Static variable in class org.apache.cassandra.db.Mutation
-
- Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.PagedRangeCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceReply
-
- Serializer(CType) - Constructor for class org.apache.cassandra.db.RangeTombstone.Serializer
-
- Serializer(CType) - Constructor for class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- serializer - Static variable in class org.apache.cassandra.db.ReadResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Row
-
- Serializer(ISerializer<IndexHelper.IndexInfo>) - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializer - Static variable in interface org.apache.cassandra.db.RowPosition
-
- serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
-
- serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Truncation
-
- serializer - Static variable in class org.apache.cassandra.db.WriteResponse
-
- serializer - Static variable in class org.apache.cassandra.dht.Token
-
- serializer - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- serializer - Static variable in class org.apache.cassandra.gms.EndpointState
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigest
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck2
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestSyn
-
- serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- Serializer(CType) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
-
- serializer - Variable in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- serializer - Variable in class org.apache.cassandra.net.CallbackInfo
-
- serializer - Variable in class org.apache.cassandra.net.MessageOut
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.CleanupMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SnapshotMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.NodePair
-
- serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
Deprecated.
- serializer - Static variable in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamSummary
-
- serializer - Static variable in class org.apache.cassandra.utils.BloomFilter
-
- 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.StreamingHistogram
-
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeValues(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- serializeValues(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- serializeValues(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- serializeValues(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- SerializingCache<K,V> - Class in org.apache.cassandra.cache
-
Serializes cache values off-heap.
- SerializingCacheProvider - Class in org.apache.cassandra.cache
-
- SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
-
- serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
-
- serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- Server - Class in org.apache.cassandra.transport
-
- Server(InetSocketAddress) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(String, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(InetAddress, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server.AbstractSecureIntializer - Class in org.apache.cassandra.transport
-
- Server.ConnectionTracker - Class in org.apache.cassandra.transport
-
- server_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- ServerConnection - Class in org.apache.cassandra.transport
-
- ServerConnection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
-
- ServerEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- ServerError - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- session - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- session - Variable in class org.apache.cassandra.streaming.StreamReader
-
- session - Variable in class org.apache.cassandra.streaming.StreamTask
-
StreamSession that this task belongs
- session - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SESSION_FAILED_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- SESSION_SUCCESS_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
-
- SessionCompleteEvent(StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- SessionCompleteEventCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionCompleteEventCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- sessionFailed() - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.SESSION_FAILED
message.
- SessionFailedMessage - Class in org.apache.cassandra.streaming.messages
-
- SessionFailedMessage() - Constructor for class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
RepairSession id
- sessionId - Variable in class org.apache.cassandra.repair.RepairSessionResult
-
- sessionId - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.SessionInfo
-
- sessionIndex - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- sessionIndex() - Method in class org.apache.cassandra.streaming.StreamSession
-
- SessionInfo - Class in org.apache.cassandra.streaming
-
Stream session info.
- SessionInfo(InetAddress, int, InetAddress, Collection<StreamSummary>, Collection<StreamSummary>, StreamSession.State) - Constructor for class org.apache.cassandra.streaming.SessionInfo
-
- SessionInfoCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- SessionPreparedEvent(UUID, SessionInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- sessions - Variable in class org.apache.cassandra.streaming.StreamState
-
- SESSIONS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
-
- set(T) - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
-
Before a task has been run, this will be called with the value from the thread that scheduled the task, and after
the task is finished, the value that was previously retrieved from this thread is restored.
- set(ExecutorLocals) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
- set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- set(ClientWarn.State) - Method in class org.apache.cassandra.service.ClientWarn
-
- set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- set(int) - 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, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- set_cql_version(String, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- set_cql_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- set_cql_version(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- set_cql_version(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
- set_cql_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.set_cql_version
-
- set_cql_version(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- set_cql_version_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- set_cql_version_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- set_cql_version_args(Cassandra.set_cql_version_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
Performs a deep copy on other.
- set_cql_version_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_cql_version_call
-
- set_cql_version_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- set_cql_version_result(InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- set_cql_version_result(Cassandra.set_cql_version_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
Performs a deep copy on other.
- set_keyspace(String, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- set_keyspace(String, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- set_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- set_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- set_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
- set_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.set_keyspace
-
- set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- set_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- set_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- set_keyspace_args(Cassandra.set_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
Performs a deep copy on other.
- set_keyspace_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
-
- set_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- set_keyspace_result(InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- set_keyspace_result(Cassandra.set_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
Performs a deep copy on other.
- setAcknowledged_by(int) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
if a write operation was acknowledged by some replicas but not by enough to
satisfy the required ConsistencyLevel, the number of successful
replies will be given here.
- setAcknowledged_by_batchlog(boolean) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
in case of atomic_batch_mutate method this field tells if the batch
was written to the batchlog.
- setAcknowledged_by_batchlogIsSet(boolean) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- setAcknowledged_byIsSet(boolean) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- setAuth_request(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- setAuth_requestIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- setAuthnx(AuthenticationException) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- setAuthnxIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- setAuthzx(AuthorizationException) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- setAuthzxIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- setAutoSnapshot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBatchSizeFailThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBatchSizeFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setBatchSizeFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for rejecting queries due to a large batch size
- setBatchSizeWarnThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBloom_filter_fp_chance(double) - Method in class org.apache.cassandra.thrift.CfDef
-
- setBloom_filter_fp_chanceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setBoundVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setBroadcastRpcAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setByte(long, byte) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- setByte(long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setByte(long, byte) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setByteBuffer(ByteBuffer, long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- setByteBuffer(ByteBuffer, long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(long, ByteBuffer) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- setBytes(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.Memory
-
- setBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from buffer to Memory
- setBytes(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
Transfers count bytes from buffer to Memory
- setBytes(long, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setBytes(byte[], int, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setCacheCapacities(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetCacheCapacity - Class in org.apache.cassandra.tools.nodetool
-
- SetCacheCapacity() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheCapacity
-
- setCacheKeysToSave(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetCacheKeysToSave - Class in org.apache.cassandra.tools.nodetool
-
- SetCacheKeysToSave() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheKeysToSave
-
- setCaching(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCachingIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCallbackForTests(int, CallbackInfo) - Method in class org.apache.cassandra.net.MessagingService
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- setCapacity(long) - Method in interface org.apache.cassandra.cache.ICache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- setCapacity(long) - Method in class org.apache.cassandra.cache.SerializingCache
-
- setCapacity(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- setCasContentionTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCasContentionTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setCasContentionTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setCells_per_row_to_cache(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCells_per_row_to_cacheIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCf_def(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- setCf_def(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- setCf_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- setCf_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- setCf_defs(List<CfDef>) - Method in class org.apache.cassandra.thrift.KsDef
-
- setCf_defsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setCfName(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setCfName(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setCfname(String) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- setCfNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setCfNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setCfnameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setColumn(CounterColumn) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setColumn(Column) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setColumn(Column) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setColumn(byte[]) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setColumn(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setColumn_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setColumn_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setColumn_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- setColumn_family(String) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setColumn_family(String) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setColumn_metadata(List<ColumnDef>) - Method in class org.apache.cassandra.thrift.CfDef
-
- setColumn_metadataIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setColumn_name(byte[]) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setColumn_name(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setColumn_nameIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setColumn_names(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setColumn_namesIsSet(boolean) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setColumn_or_supercolumn(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.Mutation
-
- setColumn_or_supercolumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Mutation
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setColumn_path(ColumnPath) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setColumn_path(ColumnPath) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setColumn_pathIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setColumn_pathIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setColumn_predicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setColumn_predicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setColumn_slices(List<ColumnSlice>) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setColumn_slicesIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setColumn_type(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setColumn_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setColumnFamily(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
-
- setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setColumns(List<CounterColumn>) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setColumns(List<Column>) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setColumns(List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setColumns(List<Column>) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setComment(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCommentIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCommit_consistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setCommit_consistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setCommitFailurePolicy(Config.CommitFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSegmentSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSync(Config.CommitLogSync) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSyncBatchWindow(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCommitLogSyncPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompaction_strategy(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompaction_strategy_options(Map<String, String>) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompaction_strategy_optionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompaction_strategyIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompactionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction parameters locally for this node
Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
- setCompactionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction parameters locally for this node
Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
- setCompactionStrategyClass(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionStrategyClass(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
Set the compaction threshold
- SetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
-
- SetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
-
- setCompactionThresholds(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionThresholds(int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum and maximum number of SSTables in queue before compaction kicks off
- setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
-
- setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- setComparator_type(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setComparator_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompression(Compression) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setCompression(Compression) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setCompression(Compression) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setCompression(Compression) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setCompression_options(Map<String, String>) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompression_optionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setCompressionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setCompressionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setCompressionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setCompressionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setCompressionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompressionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set the compression parameters
- setCompressor(FrameCompressor) - Method in class org.apache.cassandra.transport.Connection
-
- setConnectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
set hadoop cassandra connection settings
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
set hadoop cassandra connection settings
- setConnectionInformation(Configuration) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
-
Deprecated.
- setConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setConsistencyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setConsistencyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Allows user to resize core pool size of the thread pool.
- setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCount(int) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setCount(int) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setCount(int) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setCount(int) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setCount(int) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setCount(int) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setCounter_column(CounterColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setCounter_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setCounter_super_column(CounterSuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setCounter_super_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setCounterCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setCounterCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setCounterWriteRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCounterWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setCounterWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- 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
-
- setCredentials(Map<String, String>) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- setCredentialsIsSet(boolean) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- setCurrent_values(List<Column>) - Method in class org.apache.cassandra.thrift.CASResult
-
- setCurrent_valuesIsSet(boolean) - Method in class org.apache.cassandra.thrift.CASResult
-
- setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- setCustomPayload(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.transport.Message
-
- setDaemonInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDatacenter(String) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setDatacenterIsSet(boolean) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setDclocal_read_repair_chance(double) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDclocal_read_repair_chanceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDefault_name_type(String) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setDefault_name_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setDefault_time_to_live(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDefault_time_to_liveIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDefault_validation_class(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDefault_validation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setDefault_value_type(String) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setDefault_value_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setDeleteSourceOnSuccess(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setDeletion(Deletion) - Method in class org.apache.cassandra.thrift.Mutation
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
-
- setDeletionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Mutation
-
- setDescriptor(Descriptor) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- setDigest(ByteBuffer) - Method in class org.apache.cassandra.db.ReadResponse
-
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
Indicate the memory and resources owned by this allocator are no longer referenced,
and can be reclaimed/reused.
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
-
- setDiscarded() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
-
- setDiscarding(OpOrder.Barrier, AtomicReference<ReplayPosition>) - Method in class org.apache.cassandra.db.Memtable
-
- setDiscarding() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
-
Mark this allocator reclaiming; this will permit any outstanding allocations to temporarily
overshoot the maximum memory limit so that flushing can begin immediately
- setDiskAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDiskFailurePolicy(Config.DiskFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDurable_writes(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setDurable_writesIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setDynamicBadnessThreshold(Double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicResetInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setDynamicUpdateInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- SetElement(Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetElement
-
- setEnd_key(byte[]) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setEnd_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setEnd_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setEnd_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setEnd_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setEnd_token(String) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setEnd_token(String) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setEnd_token(String) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEndpoint_details(List<EndpointDetails>) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEndpoint_detailsIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEndpoints(List<String>) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEndpointsIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setEventHandler(SimpleClient.EventHandler) - Method in class org.apache.cassandra.transport.SimpleClient
-
- setExpected(List<Column>) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setExpectedIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setExpressions(List<IndexExpression>) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setExpressionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setFieldValue(AuthenticationException._Fields, Object) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- setFieldValue(AuthenticationRequest._Fields, Object) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- setFieldValue(AuthorizationException._Fields, Object) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- setFieldValue(CASResult._Fields, Object) - Method in class org.apache.cassandra.thrift.CASResult
-
- setFieldValue(Cassandra.add_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setFieldValue(Cassandra.add_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setFieldValue(Cassandra.atomic_batch_mutate_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- setFieldValue(Cassandra.atomic_batch_mutate_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setFieldValue(Cassandra.batch_mutate_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- setFieldValue(Cassandra.batch_mutate_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setFieldValue(Cassandra.cas_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setFieldValue(Cassandra.cas_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setFieldValue(Cassandra.describe_cluster_name_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- setFieldValue(Cassandra.describe_cluster_name_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- setFieldValue(Cassandra.describe_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- setFieldValue(Cassandra.describe_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setFieldValue(Cassandra.describe_keyspaces_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- setFieldValue(Cassandra.describe_keyspaces_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- setFieldValue(Cassandra.describe_local_ring_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- setFieldValue(Cassandra.describe_local_ring_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- setFieldValue(Cassandra.describe_partitioner_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- setFieldValue(Cassandra.describe_partitioner_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- setFieldValue(Cassandra.describe_ring_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- setFieldValue(Cassandra.describe_ring_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- setFieldValue(Cassandra.describe_schema_versions_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- setFieldValue(Cassandra.describe_schema_versions_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- setFieldValue(Cassandra.describe_snitch_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- setFieldValue(Cassandra.describe_snitch_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- setFieldValue(Cassandra.describe_splits_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setFieldValue(Cassandra.describe_splits_ex_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setFieldValue(Cassandra.describe_splits_ex_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- setFieldValue(Cassandra.describe_splits_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- setFieldValue(Cassandra.describe_token_map_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- setFieldValue(Cassandra.describe_token_map_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- setFieldValue(Cassandra.describe_version_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- setFieldValue(Cassandra.describe_version_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- setFieldValue(Cassandra.execute_cql3_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setFieldValue(Cassandra.execute_cql3_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setFieldValue(Cassandra.execute_cql_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setFieldValue(Cassandra.execute_cql_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setFieldValue(Cassandra.execute_prepared_cql3_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setFieldValue(Cassandra.execute_prepared_cql3_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setFieldValue(Cassandra.execute_prepared_cql_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- setFieldValue(Cassandra.execute_prepared_cql_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setFieldValue(Cassandra.get_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setFieldValue(Cassandra.get_count_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setFieldValue(Cassandra.get_count_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setFieldValue(Cassandra.get_indexed_slices_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setFieldValue(Cassandra.get_indexed_slices_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setFieldValue(Cassandra.get_multi_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- setFieldValue(Cassandra.get_multi_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setFieldValue(Cassandra.get_paged_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setFieldValue(Cassandra.get_paged_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setFieldValue(Cassandra.get_range_slices_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setFieldValue(Cassandra.get_range_slices_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setFieldValue(Cassandra.get_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setFieldValue(Cassandra.get_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setFieldValue(Cassandra.get_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setFieldValue(Cassandra.insert_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setFieldValue(Cassandra.insert_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setFieldValue(Cassandra.login_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- setFieldValue(Cassandra.login_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- setFieldValue(Cassandra.multiget_count_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setFieldValue(Cassandra.multiget_count_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setFieldValue(Cassandra.multiget_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setFieldValue(Cassandra.multiget_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setFieldValue(Cassandra.prepare_cql3_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setFieldValue(Cassandra.prepare_cql3_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- setFieldValue(Cassandra.prepare_cql_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setFieldValue(Cassandra.prepare_cql_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- setFieldValue(Cassandra.remove_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setFieldValue(Cassandra.remove_counter_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setFieldValue(Cassandra.remove_counter_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setFieldValue(Cassandra.remove_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setFieldValue(Cassandra.set_cql_version_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- setFieldValue(Cassandra.set_cql_version_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- setFieldValue(Cassandra.set_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- setFieldValue(Cassandra.set_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- setFieldValue(Cassandra.system_add_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- setFieldValue(Cassandra.system_add_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setFieldValue(Cassandra.system_add_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- setFieldValue(Cassandra.system_add_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setFieldValue(Cassandra.system_drop_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- setFieldValue(Cassandra.system_drop_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setFieldValue(Cassandra.system_drop_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- setFieldValue(Cassandra.system_drop_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setFieldValue(Cassandra.system_update_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- setFieldValue(Cassandra.system_update_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setFieldValue(Cassandra.system_update_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- setFieldValue(Cassandra.system_update_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setFieldValue(Cassandra.trace_next_query_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- setFieldValue(Cassandra.trace_next_query_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- setFieldValue(Cassandra.truncate_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- setFieldValue(Cassandra.truncate_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setFieldValue(CfDef._Fields, Object) - Method in class org.apache.cassandra.thrift.CfDef
-
- setFieldValue(CfSplit._Fields, Object) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setFieldValue(Column._Fields, Object) - Method in class org.apache.cassandra.thrift.Column
-
- setFieldValue(ColumnDef._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setFieldValue(ColumnOrSuperColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setFieldValue(ColumnParent._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setFieldValue(ColumnPath._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setFieldValue(ColumnSlice._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setFieldValue(CounterColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setFieldValue(CounterSuperColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setFieldValue(CqlMetadata._Fields, Object) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setFieldValue(CqlPreparedResult._Fields, Object) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setFieldValue(CqlResult._Fields, Object) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setFieldValue(CqlRow._Fields, Object) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setFieldValue(Deletion._Fields, Object) - Method in class org.apache.cassandra.thrift.Deletion
-
- setFieldValue(EndpointDetails._Fields, Object) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setFieldValue(IndexClause._Fields, Object) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setFieldValue(IndexExpression._Fields, Object) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setFieldValue(InvalidRequestException._Fields, Object) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- setFieldValue(KeyCount._Fields, Object) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setFieldValue(KeyRange._Fields, Object) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setFieldValue(KeySlice._Fields, Object) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setFieldValue(KsDef._Fields, Object) - Method in class org.apache.cassandra.thrift.KsDef
-
- setFieldValue(MultiSliceRequest._Fields, Object) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setFieldValue(Mutation._Fields, Object) - Method in class org.apache.cassandra.thrift.Mutation
-
- setFieldValue(NotFoundException._Fields, Object) - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- setFieldValue(SchemaDisagreementException._Fields, Object) - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- setFieldValue(SlicePredicate._Fields, Object) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setFieldValue(SliceRange._Fields, Object) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setFieldValue(SuperColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setFieldValue(TimedOutException._Fields, Object) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- setFieldValue(TokenRange._Fields, Object) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setFieldValue(TriggerDef._Fields, Object) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- setFieldValue(UnavailableException._Fields, Object) - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- setFinish(byte[]) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setFinish(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setFinish(byte[]) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setFinish(ByteBuffer) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setFinishIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setFinishIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setFSErrorHandler(FSErrorHandler) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- setGc_grace_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setGc_grace_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setGossipTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
- setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- setHintedHandoffEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setHintedHandoffEnabled(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
-
- setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setHintedHandoffEnabledByDCList(String) - Method in class org.apache.cassandra.service.StorageProxy
-
- setHintedHandoffEnabledByDCList(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setHintedHandoffThrottleInKB(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.service.StorageService
-
- setHintedHandoffThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the hinted handoff throttle in kb per second, per delivery thread.
- setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetHintedHandoffThrottleInKB - Class in org.apache.cassandra.tools.nodetool
-
- SetHintedHandoffThrottleInKB() - Constructor for class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
-
- setHost(String) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setHostIsSet(boolean) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- SetHostStat - Class in org.apache.cassandra.tools.nodetool
-
- SetHostStat(boolean) - Constructor for class org.apache.cassandra.tools.nodetool.SetHostStat
-
- setId(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setIdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setIfExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- setIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- setIgnoreHosts(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Set the hosts to ignore as comma delimited values.
- setIgnoreHosts(Configuration, String...) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
Set the hosts to ignore.
- setIncrementalBackupsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- setIncrementalBackupsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setIndex(String, IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setIndex(String, boolean) - Method in class org.apache.cassandra.cql3.IndexName
-
- setIndex_clause(IndexClause) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setIndex_clauseIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- setIndex_interval(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setIndex_intervalIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setIndex_name(String) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndex_nameIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndex_options(Map<String, String>) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndex_optionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndex_type(IndexType) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndex_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setIndexAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIndexBuilt() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexBuilt(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setIndexRemoved() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexRemoved(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexType(IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setInitialized() - Static method in class org.apache.cassandra.db.Keyspace
-
- setInputColumnFamily(Configuration, String, String, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumns(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL columns for the input of this job.
- setInputCoreConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputCQLPageRowSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL query Limit for the input of this job.
- setInputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputMaxConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputMaxSimultReqPerConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeAuthProvider(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeKeepAlive(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativePort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReadConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReceiveBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeReuseAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSendBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSolinger(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLCipherSuites(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLKeystorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLKeystorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLTruststorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeSSLTruststorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputNativeTcpNodelay(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setInputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputRange(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, String, String, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRange(Configuration, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the KeyRange to limit the rows.
- setInputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setInputSlicePredicate(Configuration, SlicePredicate) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the predicate that determines what columns will be selected from each row.
- setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the size of the input split.
- setInputSplitSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the size of the input split.
- setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL user defined where clauses for the input of this job.
- setInt(long, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- setInt(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setInterDCStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
-
- setInterDCStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setInterDCStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setInterDCStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setIsDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
-
- setItemId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setItemId(int) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- setItemId(int) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setItemIdIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setItemIdIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- setItemIdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setKey(byte[]) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setKey_alias(byte[]) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_alias(ByteBuffer) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_aliasIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_cache_save_period_in_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setKey_cache_save_period_in_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_cache_size(double) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setKey_cache_sizeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_validation_class(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKey_validation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlRow
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyCount
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeySlice
-
- setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setKeys(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setKeys(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setKeys_per_split(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setKeys_per_split(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setKeys_per_splitIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setKeys_per_splitIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setKeysIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setKeysIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.cql3.UTName
-
- setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- setKeyspace(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- setKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Update (or insert) new keyspace definition
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setKs_def(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- setKs_def(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- setKs_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- setKs_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- setLastProcessedMessageAt(long) - Method in class org.apache.cassandra.gms.Gossiper
-
- setLiveMetadata(CFMetaData) - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- setLocalHostId(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Sets the local host ID explicitly.
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
set read configuration settings
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
set read configuration settings
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- setLoggingLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
set the logging level at runtime
If both classQualifer and level are empty/null, it will reload the configuration to reset.
If classQualifer is not empty but level is empty/null, it will set the level to null for the defined classQualifer
If level cannot be parsed, then the level will be defaulted to DEBUG
The logback configuration should have < jmxConfigurator /> set
- setLoggingLevel(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetLoggingLevel - Class in org.apache.cassandra.tools.nodetool
-
- SetLoggingLevel() - Constructor for class org.apache.cassandra.tools.nodetool.SetLoggingLevel
-
- setLong(long, long) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- setLong(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setMax_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMax_compaction_thresholdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMax_index_interval(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMax_index_intervalIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMaxDataAge(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- setMaxHintsInProgress(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintsInProgress(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaxHintWindow(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setMaxHintWindow(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintWindow(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaximumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setMaximumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum number of sstables in queue before compaction kicks off
- setMaximumCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Allows user to resize maximum size of the thread pool.
- setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the validator thread pool.
- setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setMemoryPoolCapacityInMB(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- setMemoryPoolCapacityInMB(long) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- setMemtable_flush_after_mins(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setMemtable_flush_after_minsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMemtable_flush_period_in_ms(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMemtable_flush_period_in_msIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMemtable_operations_in_millions(double) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setMemtable_operations_in_millionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMemtable_throughput_in_mb(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setMemtable_throughput_in_mbIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMerge_shards_chance(double) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setMerge_shards_chanceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMetadata(KSMetaData) - Method in class org.apache.cassandra.db.Keyspace
-
- setMin_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMin_compaction_thresholdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMin_index_interval(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMin_index_intervalIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
- setMutation_map(Map<ByteBuffer, Map<String, List<Mutation>>>) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- setMutation_map(Map<ByteBuffer, Map<String, List<Mutation>>>) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- setMutation_mapIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- setMutation_mapIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- setName(String, boolean) - Method in class org.apache.cassandra.cql3.RoleName
-
- setName(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setName(byte[]) - Method in class org.apache.cassandra.thrift.Column
-
- setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.Column
-
- setName(byte[]) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setName(byte[]) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setName(byte[]) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setName(String) - Method in class org.apache.cassandra.thrift.KsDef
-
- setName(byte[]) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setName(String) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- setName_types(Map<ByteBuffer, String>) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setName_typesIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.SuperColumn
-
- setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- setNativeTransportMaxConcurrentConnections(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setNativeTransportMaxConcurrentConnections(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setNativeTransportMaxConcurrentConnections(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setNativeTransportMaxConcurrentConnectionsPerIp(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setNativeTransportMaxConcurrentConnectionsPerIp(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setNewLocalCompactionStrategy(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- setNfe(NotFoundException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setNfe(NotFoundException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setNfeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setNfeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setNum(int) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setNumIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setOp(IndexOperator) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- setOpIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setOption(IRoleManager.Option, Object) - Method in class org.apache.cassandra.auth.RoleOptions
-
Set a value for a specific option.
- setOptions(Map<String, String>) - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
Sets an implementation defined set of options.
- setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- setOptionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.TriggerDef
-
- setOrdering(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- setOrListToJsonString(ByteBuffer, AbstractType, int) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- setOtcCoalescingEnoughCoalescedMessages(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setOutboundBindAny(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL prepared statement for the output of this job.
- setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace for the output of this job.
- setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputLocalDCOnly(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setPartitioner(IPartitioner) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPartitioner(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
set partition filter
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- setPath(ColumnPath) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setPathIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- setPaxos_in_progress(boolean) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
for the CAS method, this field tells if we timed out during the paxos
protocol, as opposed to during the commit of our update
- setPaxos_in_progressIsSet(boolean) - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- setPermissionsUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPermissionsValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPhiConvictThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPhiConvictThreshold(double) - Method in class org.apache.cassandra.gms.FailureDetector
-
- setPhiConvictThreshold(double) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- setPopulate_io_cache_on_flush(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setPopulate_io_cache_on_flushIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setPostFlushListener(Runnable) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Deletion
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
-
- setQuery(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setQuery(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setQuery(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setQuery(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setQuery(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setQuery(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setQuery(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setQuery(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setQueryIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- setQueryIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- setQueryIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- setQueryIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- setRack(String) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setRackIsSet(boolean) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setRange(KeyRange) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setRange(KeyRange) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
The number of rows to request with each get range slices request.
- setRangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setRangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- 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
-
- setRate(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Sets the rate for the rate limiter.
- setRead_repair_chance(double) - Method in class org.apache.cassandra.thrift.CfDef
-
- setRead_repair_chanceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- setReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- setReplicate_on_write(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setReplicate_on_writeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setReplication_factor(int) - Method in class org.apache.cassandra.thrift.KsDef
-
- setReplication_factorIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setRequest(MultiSliceRequest) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- setRequestIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- setReversed(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setReversed(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setReversedIsSet(boolean) - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- setReversedIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setRolesUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRolesValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRow_cache_keys_to_save(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setRow_cache_keys_to_saveIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setRow_cache_provider(String) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setRow_cache_providerIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setRow_cache_save_period_in_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setRow_cache_save_period_in_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setRow_cache_size(double) - Method in class org.apache.cassandra.thrift.CfDef
-
Deprecated.
- setRow_cache_sizeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setRow_count(long) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setRow_countIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setRow_filter(List<IndexExpression>) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setRow_filterIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRowCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRowCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setRowCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setRowCacheSizeInMB(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRows(List<CqlRow>) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setRowsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setRpc_endpoints(List<String>) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setRpc_endpointsIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setRpcReady(boolean) - Method in class org.apache.cassandra.service.StorageService
-
- setRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- Sets - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for sets.
- Sets.Adder - Class in org.apache.cassandra.cql3
-
- Sets.DelayedValue - Class in org.apache.cassandra.cql3
-
- Sets.Discarder - Class in org.apache.cassandra.cql3
-
- Sets.ElementDiscarder - Class in org.apache.cassandra.cql3
-
- Sets.Literal - Class in org.apache.cassandra.cql3
-
- Sets.Marker - Class in org.apache.cassandra.cql3
-
- Sets.Setter - Class in org.apache.cassandra.cql3
-
- Sets.Value - Class in org.apache.cassandra.cql3
-
- setSchema(CqlMetadata) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setSchemaIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setSde(SchemaDisagreementException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setSdeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setSerial_consistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setSerial_consistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- 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.
- setShort(long, short) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- setShort(long, short) - Method in class org.apache.cassandra.io.util.Memory
-
- setShort(long, short) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
-
- setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- setSlice_range(SliceRange) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setSlice_rangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setSourceFrame(Frame) - Method in class org.apache.cassandra.transport.Message
-
- setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- setSpeculative_retry(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setSpeculative_retryIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setSSTableFormatType(SSTableFormat.Type) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- setSSTablePreempiveOpenIntervalInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setStart(Composite) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- setStart(byte[]) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setStart(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setStart(byte[]) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setStart(ByteBuffer) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setStart_column(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setStart_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setStart_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- setStart_key(byte[]) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setStart_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setStart_key(byte[]) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setStart_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setStart_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- setStart_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setStart_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setStart_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setStart_token(String) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setStart_token(String) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setStart_token(String) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfSplit
-
- setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
-
- setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
-
- setStartIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- setStartIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setStatus(TaskAttemptContext, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
Invoke setStatus() on TaskAttemptContext.
- setStatus(String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
StoreFunc methods
- setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
StoreFunc methods
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
set store configuration settings
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
set store configuration settings
- setStrategy_class(String) - Method in class org.apache.cassandra.thrift.KsDef
-
- setStrategy_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setStrategy_options(Map<String, String>) - Method in class org.apache.cassandra.thrift.KsDef
-
- setStrategy_optionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
-
- setStreamFactory(AutoSavingCache.IStreamFactory) - Static method in class org.apache.cassandra.cache.AutoSavingCache
-
- setStreamId(int) - Method in class org.apache.cassandra.transport.Message
-
- setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
-
- SetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetStreamThroughput
-
- setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setSubcomparator_type(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setSubcomparator_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setSubtype(int, AbstractType<?>) - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Returns a new CellNameType that is equivalent to this one but with one
of the subtype replaced by the provided new type.
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundCType
-
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
-
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
-
- setSubtype(int, AbstractType<?>) - Method in interface org.apache.cassandra.db.composites.CType
-
Returns a new CType that is equivalent to this CType but with
one of the subtype replaced by the provided new type.
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- setSuccess(boolean) - Method in class org.apache.cassandra.thrift.CASResult
-
- setSuccess(CASResult) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- setSuccess(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setSuccess(List<KsDef>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- setSuccess(List<TokenRange>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- setSuccess(List<TokenRange>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- setSuccess(Map<String, List<String>>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- setSuccess(List<CfSplit>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- setSuccess(List<String>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- setSuccess(Map<String, String>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- setSuccess(CqlResult) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setSuccess(CqlResult) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setSuccess(CqlResult) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setSuccess(CqlResult) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setSuccess(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setSuccess(List<KeySlice>) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setSuccess(List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setSuccess(List<KeySlice>) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setSuccess(List<KeySlice>) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setSuccess(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setSuccess(List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setSuccess(Map<ByteBuffer, Integer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setSuccess(Map<ByteBuffer, List<ColumnOrSuperColumn>>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setSuccess(CqlPreparedResult) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- setSuccess(CqlPreparedResult) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setSuccess(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- setSuccess(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.CASResult
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- setSuper_column(SuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.Deletion
-
- setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.Deletion
-
- setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnParent
-
- setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
-
- setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
-
- setTableAlias(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setTableInsertStatement(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
-
- setTableSchema(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
-
- Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
-
- SetterByIndex(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- SetterByKey(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
-
- setThriftFramedTransportSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Sets the socket timeout
- setTimestamp(long) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setTimestamp(long) - Method in class org.apache.cassandra.thrift.Column
-
- setTimestamp(long) - Method in class org.apache.cassandra.thrift.Deletion
-
- setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
-
- setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
-
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- setTombstoneFailureThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTombstoneFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setTombstoneFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for abandoning queries with many tombstones
- setTombstoneWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTombstoneWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
- setTombstoneWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for warning queries with many tombstones
- setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
-
- setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Enables/Disables tracing for the whole system.
- setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetTraceProbability - Class in org.apache.cassandra.tools.nodetool
-
- SetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.SetTraceProbability
-
- setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
-
- setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- setTriggers(List<TriggerDef>) - Method in class org.apache.cassandra.thrift.CfDef
-
- setTriggersIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- setTtl(int) - Method in class org.apache.cassandra.thrift.Column
-
- setTtlIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
-
- setTupleValue(Tuple, int, Object) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
-
Deprecated.
set the value to the position of the tuple
- SetType<T> - Class in org.apache.cassandra.db.marshal
-
- SetType(AbstractType<T>, boolean) - Constructor for class org.apache.cassandra.db.marshal.SetType
-
- setType(CqlResultType) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setTypeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlResult
-
- setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Setup is called once upon system startup to initialize the IAuthorizer.
- setup() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Hook to perform implementation specific initialization, called once upon system startup.
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- setupCompleted() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- setUpdateInterval(int) - Method in class org.apache.cassandra.auth.PermissionsCache
-
- setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- setUpdateInterval(int) - Method in class org.apache.cassandra.auth.RolesCache
-
- setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.RolesCacheMBean
-
- setUpdates(List<Column>) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setUpdatesIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
Deprecated.
- setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- setupKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
Deprecated.
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
-
- setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- setValidation_class(String) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setValidation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setValidity(int) - Method in class org.apache.cassandra.auth.PermissionsCache
-
- setValidity(int) - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- setValidity(int) - Method in class org.apache.cassandra.auth.RolesCache
-
- setValidity(int) - Method in interface org.apache.cassandra.auth.RolesCacheMBean
-
- SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
-
- setValue(byte[]) - Method in class org.apache.cassandra.thrift.Column
-
- setValue(ByteBuffer) - Method in class org.apache.cassandra.thrift.Column
-
- setValue(long) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setValue(byte[]) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setValue(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setValue_types(Map<ByteBuffer, String>) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setValue_typesIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- setValueIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
-
- setValueIsSet(boolean) - Method in class org.apache.cassandra.thrift.CounterColumn
-
- setValueIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- setValues(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setValues(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- setValuesIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- setValuesIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- setVariable_names(List<String>) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setVariable_namesIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setVariable_types(List<String>) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setVariable_typesIsSet(boolean) - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- setVersion(InetAddress, int) - Method in class org.apache.cassandra.net.MessagingService
-
- setVersion(String) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- setVersionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- setWarnings(List<String>) - Method in class org.apache.cassandra.transport.Message.Response
-
- setWhy(String) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- setWhy(String) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- setWhy(String) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- 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
-
- SHARED - Static variable in class org.apache.cassandra.concurrent.SharedExecutorPool
-
- SharedCloseable - Interface in org.apache.cassandra.utils.concurrent
-
A simple extension of AutoCloseable, that represents a resource that can be utilised in multiple locations,
each managing their own closure of the resource, so that when the last such instance is closed all are.
- SharedCloseableImpl - Class in org.apache.cassandra.utils.concurrent
-
A simple abstract implementation of SharedCloseable
- SharedCloseableImpl(RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- SharedCloseableImpl(SharedCloseableImpl) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- sharedCopy() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- sharedCopy() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- sharedCopy() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- sharedCopy() - Method in class org.apache.cassandra.utils.BloomFilter
-
- sharedCopy() - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
-
- SharedExecutorPool - Class in org.apache.cassandra.concurrent
-
A pool of worker threads that are shared between all Executors created with it.
- SharedExecutorPool(String) - Constructor for class org.apache.cassandra.concurrent.SharedExecutorPool
-
- ShortSerializer - Class in org.apache.cassandra.serializers
-
- ShortSerializer() - Constructor for class org.apache.cassandra.serializers.ShortSerializer
-
- ShortType - Class in org.apache.cassandra.db.marshal
-
- shouldBeEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- shouldClearLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- shouldDefragment() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- shouldDefragment() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- shouldDefragment() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- shouldHint() - Method in class org.apache.cassandra.net.CallbackInfo
-
- shouldHint() - Method in class org.apache.cassandra.net.WriteCallbackInfo
-
- shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
-
- shouldHintByDC() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- shouldInclude(SSTableReader) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- shouldInclude(InetAddress) - Method in interface org.apache.cassandra.dht.RangeStreamer.ISourceFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- shouldListenOnBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- shouldLogAverage - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- shouldPullSchemaFrom(InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
-
- shouldReplay(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
-
- shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- shutdown() - Static method in class org.apache.cassandra.db.BatchlogManager
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
Initiates the shutdown process for the management thread.
- shutdown() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Releases any resources if this strategy is shutdown (when the CFS is reloaded after a schema change).
- shutdown() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- SHUTDOWN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- shutdown(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- shutdown() - Method in class org.apache.cassandra.net.MessagingService
-
Wait for callbacks and don't allow any more to be created (since they could require writing hints)
- shutdown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Shuts down the threads used by the commit log, blocking until completion.
- shutdownBlocking() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- shutdownGracefully(long, long, TimeUnit) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
-
This method shuts down all registered stages.
- shutdownNow() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- shutdownPostFlushExecutor() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SigarLibrary - Class in org.apache.cassandra.utils
-
- signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- signal() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- signal() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal one waiting thread
- signalAll() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- signalAll() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal all waiting threads
- SimpleCBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
-
- SimpleClient - Class in org.apache.cassandra.transport
-
- SimpleClient(String, int, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient.EventHandler - Interface in org.apache.cassandra.transport
-
- SimpleClient.SimpleEventHandler - Class in org.apache.cassandra.transport
-
- SimpleComposite - Class in org.apache.cassandra.db.composites
-
A "simple" (not-truly-composite) Composite.
- simpleCondition(Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
A condition on a column.
- SimpleCondition - Class in org.apache.cassandra.utils.concurrent
-
- SimpleCondition() - Constructor for class org.apache.cassandra.utils.concurrent.SimpleCondition
-
- SimpleCType - Class in org.apache.cassandra.db.composites
-
A not truly-composite CType.
- SimpleCType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleCType
-
- SimpleCType.SimpleCBuilder - Class in org.apache.cassandra.db.composites
-
- SimpleDateSerializer - Class in org.apache.cassandra.serializers
-
- SimpleDateSerializer() - Constructor for class org.apache.cassandra.serializers.SimpleDateSerializer
-
- SimpleDateType - Class in org.apache.cassandra.db.marshal
-
- simpleDense(ByteBuffer) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- SimpleDenseCellName - Class in org.apache.cassandra.db.composites
-
- SimpleDenseCellNameType - Class in org.apache.cassandra.db.composites
-
- SimpleDenseCellNameType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleDenseCellNameType
-
- SimpleEventHandler() - Constructor for class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
-
- simpleInCondition(List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a column.
- simpleInCondition(AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
An IN condition on a column with a single marker.
- simpleMapping(Iterable<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
-
- SimpleSeedProvider - Class in org.apache.cassandra.locator
-
- SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
-
- SimpleSelector - Class in org.apache.cassandra.cql3.selection
-
- SimpleSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that treats Strategy order as proximity,
allowing non-read-repaired reads to prefer a single endpoint, which improves
cache locality.
- SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
-
- simpleSparse(ColumnIdentifier) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- SimpleSparseCellName - Class in org.apache.cassandra.db.composites
-
- SimpleSparseCellNameType - Class in org.apache.cassandra.db.composites
-
- SimpleSparseCellNameType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleSparseCellNameType
-
- SimpleSparseInternedCellName - Class in org.apache.cassandra.db.composites
-
- SimpleStrategy - Class in org.apache.cassandra.locator
-
This class returns the nodes responsible for a given
key but does not respect rack awareness.
- SimpleStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleStrategy
-
- simulateFailedFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SingleColumnRelation - Class in org.apache.cassandra.cql3
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- SingleColumnRelation(ColumnIdentifier.Raw, Term.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRelation(ColumnIdentifier.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
-
- SingleColumnRestriction.Contains - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.EQ - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.IN - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.InWithMarker - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.InWithValues - Class in org.apache.cassandra.cql3.restrictions
-
- SingleColumnRestriction.Slice - Class in org.apache.cassandra.cql3.restrictions
-
- SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- SinglePartitionPager - Interface in org.apache.cassandra.service.pager
-
Common interface to single partition queries (by slice and by name).
- singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- size() - Method in interface org.apache.cassandra.cache.ICache
-
- size() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- size() - Method in class org.apache.cassandra.cache.SerializingCache
-
- size() - Method in class org.apache.cassandra.cql3.ResultSet
-
- size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- size() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- size() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- size() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- size() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- size() - Method in class org.apache.cassandra.db.composites.BoundedComposite
-
- size() - Method in interface org.apache.cassandra.db.composites.Composite
-
- size() - Method in class org.apache.cassandra.db.composites.CompoundComposite
-
- size() - Method in class org.apache.cassandra.db.composites.CompoundCType
-
- size() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- size() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
-
- size() - Method in interface org.apache.cassandra.db.composites.CType
-
The number of subtypes for this CType.
- size() - Method in class org.apache.cassandra.db.composites.SimpleComposite
-
- size() - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- size() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
-
- size() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- size() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- size() - Method in class org.apache.cassandra.io.util.ChannelProxy
-
- size - Variable in class org.apache.cassandra.io.util.Memory
-
- size() - Method in class org.apache.cassandra.io.util.Memory
-
- size - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total size of cache, in bytes
- size() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Return the number of buckets where recorded values are stored.
- size - 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.tools.nodetool.SetHostStat
-
- size() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- size() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- size() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
- size() - Method in class org.apache.cassandra.utils.concurrent.Refs
-
- size() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- size() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- size - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- size() - Method in class org.apache.cassandra.utils.MerkleTree
-
The number of distinct ranges contained in this tree.
- size() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity of this set.
- SIZE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SizeComparator() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.SizeComparator
-
- SizeEstimatesRecorder - Class in org.apache.cassandra.db
-
A very simplistic/crude partition count/size estimator.
- sizeInBytes() - Method in class org.apache.cassandra.service.FileCacheService
-
- sizeOf(Cell) - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- sizeOf(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- sizeOf(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(String) - Method in class org.apache.cassandra.db.TypeSizes
-
assumes UTF8
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeOf(String) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a String consumes
- sizeOfArray(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte array consumes
- sizeOfArray(long[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a long array consumes
- sizeOfArray(int[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory an int array consumes
- sizeOfArray(Object[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a reference array consumes itself only
- sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfBytesMap(Map<String, ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfCollectionSize(int, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- sizeOfConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfEnumValue(T) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfInet(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfLongString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfReferenceArray(int) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a reference array consumes
- sizeOfString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringList(List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringMap(Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringToStringListMap(Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- sizeOfValue(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeofVInt(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeofWithLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithShortLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeOnHeapExcludingData(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- sizeOnHeapExcludingData(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- sizeOnHeapOf(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a ByteBuffer array consumes.
- sizeOnHeapOf(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte buffer consumes
- sizeOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- sizeOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- sizeTieredOptions - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- skip(DataInput) - Method in interface org.apache.cassandra.db.composites.CType.Serializer
-
- skip(DataInput) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
-
- skip(DataInput) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Skips count
number of bytes in this InputStream.
- skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- SKIP_SYNC - Static variable in class org.apache.cassandra.utils.SyncUtil
-
- skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- skipBody(DataInput, Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- skipIndex(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
Skip the index
- skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- skipNext() - Method in class org.apache.cassandra.db.AtomDeserializer
-
Skips the next atom.
- skipNext() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
-
Skip the next name (consuming it).
- skipShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SlabAllocator - Class in org.apache.cassandra.utils.memory
-
+ * The SlabAllocator is a bump-the-pointer allocator that allocates
+ * large (1MB) global regions and then doles them out to threads that
+ * request smaller sized (up to 128kb) slices into the array.
- SlabPool - Class in org.apache.cassandra.utils.memory
-
- SlabPool(long, long, float, Runnable) - Constructor for class org.apache.cassandra.utils.memory.SlabPool
-
- Slice(List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
-
- Slice(ColumnDefinition, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
-
- Slice(CType, List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
-
- slice() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- slice() - Method in class org.apache.cassandra.db.composites.AbstractComposite
-
- slice() - Method in interface org.apache.cassandra.db.composites.Composite
-
- slice(Object[], boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Returns an Iterator over the entire tree
- slice(Object[], Comparator<K>, K, K, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Returns an Iterator over a sub-range of the tree
- slice(Object[], Comparator<K>, K, boolean, K, boolean, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Returns an Iterator over a sub-range of the tree
- slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- slice_range - Variable in class org.apache.cassandra.thrift.SlicePredicate
-
- SliceByNamesReadCommand - Class in org.apache.cassandra.db
-
- SliceByNamesReadCommand(String, ByteBuffer, String, long, NamesQueryFilter) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
-
- sliceBytes(ByteBuffer, int, int) - Static method in class org.apache.cassandra.db.composites.AbstractCType
-
- SliceFromReadCommand - Class in org.apache.cassandra.db
-
- SliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
-
- SlicePredicate - Class in org.apache.cassandra.thrift
-
A SlicePredicate is similar to a mathematic predicate (see http://en.wikipedia.org/wiki/Predicate_(mathematical_logic)),
which is described as "a property that the elements of a set have in common."
SlicePredicate's in Cassandra are described with either a list of column_names or a SliceRange.
- SlicePredicate() - Constructor for class org.apache.cassandra.thrift.SlicePredicate
-
- SlicePredicate(SlicePredicate) - Constructor for class org.apache.cassandra.thrift.SlicePredicate
-
Performs a deep copy on other.
- SlicePredicate._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- SliceQueryFilter - Class in org.apache.cassandra.db.filter
-
- SliceQueryFilter(Composite, Composite, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(Composite, Composite, boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ColumnSlice, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ColumnSlice, boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ColumnSlice[], boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
Constructor that accepts multiple slices.
- SliceQueryFilter(ColumnSlice[], boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- sliceQueryFilterSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- sliceQueryFilterSerializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- SliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pager over a SliceFromReadCommand.
- SliceRange - Class in org.apache.cassandra.thrift
-
A slice range is a structure that stores basic range, ordering and limit information for a query that will return
multiple columns.
- SliceRange() - Constructor for class org.apache.cassandra.thrift.SliceRange
-
- SliceRange(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.thrift.SliceRange
-
- SliceRange(SliceRange) - Constructor for class org.apache.cassandra.thrift.SliceRange
-
Performs a deep copy on other.
- SliceRange._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- slices - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- sliceSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- sliceSerializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- smallMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for small message TCP Connections
- smallMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for small message TCP Connections
- smallMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for small message TCP Connections
- smallMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- SnappyCompressor - Class in org.apache.cassandra.io.compress
-
- SnappyCompressor() - Constructor for class org.apache.cassandra.io.compress.SnappyCompressor
-
- snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Take a snap shot of this columnfamily store.
- snapshot(String, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshot(String, String) - Method in class org.apache.cassandra.db.Keyspace
-
Take a snapshot of the specific column family, or the entire set of column families
if columnFamily is null with a given timestamp
- Snapshot - Class in org.apache.cassandra.tools.nodetool
-
- Snapshot() - Constructor for class org.apache.cassandra.tools.nodetool.Snapshot
-
- snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
-
- snapshot_name - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- SNAPSHOT_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
-
- SnapshotCommand - Class in org.apache.cassandra.db
-
- SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
-
- snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
-
- SnapshotDeletingTask - Class in org.apache.cassandra.io.sstable
-
- SnapshotDetailsTabularData - Class in org.apache.cassandra.db
-
- SnapshotDetailsTabularData() - Constructor for class org.apache.cassandra.db.SnapshotDetailsTabularData
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Directories
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Keyspace
-
Check whether snapshots already exists for a given name.
- SnapshotMessage - Class in org.apache.cassandra.repair.messages
-
- SnapshotMessage(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage
-
- SnapshotMessage.SnapshotMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- SnapshotMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
-
- snapshotOnVersionChange() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Compare the release version in the system.local table with the one included in the distro.
- snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SnapshotTask - Class in org.apache.cassandra.repair
-
SnapshotTask is a task that sends snapshot request.
- SnapshotTask(RepairJobDesc, InetAddress) - Constructor for class org.apache.cassandra.repair.SnapshotTask
-
- SnapshotVerbHandler - Class in org.apache.cassandra.service
-
- SnapshotVerbHandler() - Constructor for class org.apache.cassandra.service.SnapshotVerbHandler
-
- snapshotWithoutFlush(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshotWithoutFlush(String, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- SNITCH_PROPERTIES_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
-
- SnitchProperties - Class in org.apache.cassandra.locator
-
- SnitchProperties() - Constructor for class org.apache.cassandra.locator.SnitchProperties
-
- socket - Variable in class org.apache.cassandra.net.IncomingStreamingConnection
-
- socket - Variable in class org.apache.cassandra.transport.Server
-
- SOCKET_TIMEOUT - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- SOFTIRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the List of node addresses, in-place, by proximity to the given address
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- sortByProximity(InetAddress, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
This method will sort the List by proximity to the given address.
- sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- sorted() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Creates a CQLSSTableWriter that expects sorted inputs.
- SortedBiMultiValMap<K,V> - Class in org.apache.cassandra.utils
-
- SortedBiMultiValMap(SortedMap<K, V>, SortedSetMultimap<V, K>) - Constructor for class org.apache.cassandra.utils.SortedBiMultiValMap
-
- sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- sparseCFMetaData(String, String, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- speculative_retry - Variable in class org.apache.cassandra.thrift.CfDef
-
- speculativeRetries - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- speculativeRetry(CFMetaData.SpeculativeRetry) - Method in class org.apache.cassandra.config.CFMetaData
-
- split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
-
- split(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the provided readers from this Transaction, and return a new Transaction to manage them
only permitted to be called if the current Transaction has never been used
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Split a composite column names into it's components.
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
Split a tuple value into its component values.
- split(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?),
where ? means that the same type of AbstractBounds is returned as the original.
- split(T) - Method in class org.apache.cassandra.dht.Bounds
-
- split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.Range
-
- split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Splits the range containing the given token, if no tree limits would be
violated.
- SplitController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- splitOutStaticSlice(CFMetaData) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
Splits this filter into two SliceQueryFilters: one that slices only the static columns, and one that slices the
remainder of the normal data.
- splitSize - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
Deprecated.
- splitSize - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- SplittingCompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- SplittingSizeTieredCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
-
CompactionAwareWriter that splits input in differently sized sstables
Biggest sstable will be total_compaction_size / 2, second biggest total_compaction_size / 4 etc until
the result would be sub 50MB, all those are put in the same
- SplittingSizeTieredCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- SplittingSizeTieredCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, OperationType, long) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
-
- src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ssl_storage_port - Variable in class org.apache.cassandra.config.Config
-
- SSLFactory - Class in org.apache.cassandra.security
-
A Factory for providing and setting up Client and Server SSL wrapped
Socket and ServerSocket
- SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
-
- SSLTransportFactory - Class in org.apache.cassandra.thrift
-
- SSLTransportFactory() - Constructor for class org.apache.cassandra.thrift.SSLTransportFactory
-
- sstable - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
-
- SSTable - Class in org.apache.cassandra.io.sstable
-
This class is built on top of the SequenceFile.
- SSTable(Descriptor, 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.notifications.SSTableRepairStatusChanged
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SSTABLE_ACTIVITY - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- sstable_preemptive_open_interval_in_mb - Variable in class org.apache.cassandra.config.Config
-
- 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.format.SSTableReader
-
- sstableCompressor - Variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- SSTableDeletingNotification - Class in org.apache.cassandra.notifications
-
Fired right before removing an SSTable.
- SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- SSTableDeletingTask - Class in org.apache.cassandra.io.sstable
-
- SSTableDeletingTask(Descriptor, Set<Component>, Counter, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
realDescriptor is the actual descriptor for the sstable, the descriptor inside
referent can be 'faked' as FINAL for early opened files.
- SSTableExpiredBlockers - Class in org.apache.cassandra.tools
-
During compaction we can drop entire sstables if they only contain expired tombstones and if it is guaranteed
to not cover anything in other sstables.
- SSTableExpiredBlockers() - Constructor for class org.apache.cassandra.tools.SSTableExpiredBlockers
-
- SSTableExport - Class in org.apache.cassandra.tools
-
Export SSTables to JSON format.
- SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
-
- SSTableFormat - Interface in org.apache.cassandra.io.sstable.format
-
Provides the accessors to data on disk.
- SSTableFormat.Type - Enum in org.apache.cassandra.io.sstable.format
-
- SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableImport - Class in org.apache.cassandra.tools
-
Create SSTables from JSON input
- SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(Integer, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableIntervalTree - Class in org.apache.cassandra.db.lifecycle
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- sstableLevel - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sstableLevel - Variable in class org.apache.cassandra.streaming.StreamReader
-
- SSTableLevelResetter - Class in org.apache.cassandra.tools
-
Reset level to 0 on a given set of sstables
- SSTableLevelResetter() - Constructor for class org.apache.cassandra.tools.SSTableLevelResetter
-
- SSTableListChangedNotification - Class in org.apache.cassandra.notifications
-
- SSTableListChangedNotification(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- sstableLister() - Method in class org.apache.cassandra.db.Directories
-
- SSTableLister() - Constructor for class org.apache.cassandra.db.Directories.SSTableLister
-
- SSTableLoader - Class in org.apache.cassandra.io.sstable
-
Cassandra SSTable bulk loader.
- SSTableLoader(File, SSTableLoader.Client, OutputHandler) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
-
- SSTableLoader(File, SSTableLoader.Client, OutputHandler, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
-
- SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
-
- sstableMap - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- sstableMetadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableMetadataViewer - Class in org.apache.cassandra.tools
-
Shows the contents of sstable metadata
- SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
-
- SSTableOfflineRelevel - Class in org.apache.cassandra.tools
-
Create a decent leveling for the given keyspace/column family
Approach is to sort the sstables by their last token
given an original leveling like this (note that [ ] indicates token boundaries, not sstable size on disk, all sstables are the same size)
L3 [][][][][][][][][][][]
L2 [ ][ ][ ][ ]
L1 [ ][ ]
L0 [ ]
Will look like this after being dropped to L0 and sorted by last token (and, to illustrate overlap, the overlapping ones are put on a new line):
[][][]
[ ][][][]
[ ]
[ ]
...
- SSTableOfflineRelevel() - Constructor for class org.apache.cassandra.tools.SSTableOfflineRelevel
-
- sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableReader - Class in org.apache.cassandra.io.sstable.format
-
An SSTableReader can be constructed in a number of places, but typically is either
read from disk at startup, or constructed from a flushed memtable, or after compaction
to replace some existing sstables.
- SSTableReader(Descriptor, Set<Component>, CFMetaData, IPartitioner, long, StatsMetadata, SSTableReader.OpenReason) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
-
- SSTableReader.Factory - Class in org.apache.cassandra.io.sstable.format
-
- SSTableReader.OpenReason - Enum in org.apache.cassandra.io.sstable.format
-
- SSTableReader.Operator - Class in org.apache.cassandra.io.sstable.format
-
TODO: Move someplace reusable
- SSTableReader.SizeComparator - Class in org.apache.cassandra.io.sstable.format
-
- SSTableReader.UniqueIdentifier - Class in org.apache.cassandra.io.sstable.format
-
- SSTableRepairedAtSetter - Class in org.apache.cassandra.tools
-
Set repairedAt status on a given set of sstables.
- SSTableRepairedAtSetter() - Constructor for class org.apache.cassandra.tools.SSTableRepairedAtSetter
-
- SSTableRepairStatusChanged - Class in org.apache.cassandra.notifications
-
- SSTableRepairStatusChanged(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.notifications.SSTableRepairStatusChanged
-
- SSTableRewriter - Class in org.apache.cassandra.io.sstable
-
Wraps one or more writers as output for rewriting one or more readers: every sstable_preemptive_open_interval_in_mb
we look in the summary we're collecting for the latest writer for the penultimate key that we know to have been fully
flushed to the index file, and then double check that the key is fully present in the flushed data file.
- SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- sstables - Variable in class org.apache.cassandra.db.lifecycle.View
-
- sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
-
- SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
-
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
Create a new buffering writer.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
-
- SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Deprecated.
Create a new writer.
- SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Deprecated.
- sstablesInBounds(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.lifecycle.View
-
Returns the sstables that have any partition between left
and right
, when both bounds are taken inclusively.
- sstablesInBounds(RowPosition, RowPosition, SSTableIntervalTree) - Static method in class org.apache.cassandra.db.lifecycle.View
-
- sstablesMap - Variable in class org.apache.cassandra.db.lifecycle.View
-
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Histogram of the number of sstable data files accessed per read
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Histogram of the number of sstable data files accessed per read
- SSTableSplitter - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
-
- SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
-
- sstablesRewrite(boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SSTableStreamingSections(Ref<SSTableReader>, List<Pair<Long, Long>>, long, long) - Constructor for class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sstableWriter - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
- SSTableWriter - Class in org.apache.cassandra.io.sstable.format
-
This is the API all table writers must implement.
- SSTableWriter(Descriptor, long, long, CFMetaData, IPartitioner, MetadataCollector) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- SSTableWriter.Factory - Class in org.apache.cassandra.io.sstable.format
-
- SSTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
-
- Stage - Enum in org.apache.cassandra.concurrent
-
- StageManager - Class in org.apache.cassandra.concurrent
-
This class manages executor services for Messages recieved: each Message requests
running on a specific "stage" for concurrency control; hence the Map approach,
even though stages (executors) are not created dynamically.
- StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
-
- StandaloneScrubber - Class in org.apache.cassandra.tools
-
- StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
-
- StandaloneSplitter - Class in org.apache.cassandra.tools
-
- StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
-
- StandaloneUpgrader - Class in org.apache.cassandra.tools
-
- StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
-
- StandaloneVerifier - Class in org.apache.cassandra.tools
-
- StandaloneVerifier() - Constructor for class org.apache.cassandra.tools.StandaloneVerifier
-
- start() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- start() - Method in class org.apache.cassandra.db.BatchlogManager
-
- start() - Method in class org.apache.cassandra.db.composites.AbstractComposite
-
- start() - Method in interface org.apache.cassandra.db.composites.Composite
-
- start - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- start() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- start() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- start - Variable in class org.apache.cassandra.db.PagedRangeCommand
-
- start(int) - Method in class org.apache.cassandra.gms.Gossiper
-
- start(int, Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.Gossiper
-
Start the gossiper with the generation number, preloading the map of application states before starting
- start() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- start(ListeningExecutorService) - Method in class org.apache.cassandra.repair.RepairSession
-
Start RepairJob on given ColumnFamilies.
- start - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Start the server.
- start() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
-
- start() - Method in class org.apache.cassandra.streaming.StreamSession
-
- start(I, Cassandra.add_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.add
-
- start(I, Cassandra.atomic_batch_mutate_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.atomic_batch_mutate
-
- start(I, Cassandra.batch_mutate_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.batch_mutate
-
- start(I, Cassandra.cas_args, AsyncMethodCallback<CASResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- start(I, Cassandra.describe_cluster_name_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_cluster_name
-
- start(I, Cassandra.describe_keyspace_args, AsyncMethodCallback<KsDef>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspace
-
- start(I, Cassandra.describe_keyspaces_args, AsyncMethodCallback<List<KsDef>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspaces
-
- start(I, Cassandra.describe_local_ring_args, AsyncMethodCallback<List<TokenRange>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_local_ring
-
- start(I, Cassandra.describe_partitioner_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_partitioner
-
- start(I, Cassandra.describe_ring_args, AsyncMethodCallback<List<TokenRange>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_ring
-
- start(I, Cassandra.describe_schema_versions_args, AsyncMethodCallback<Map<String, List<String>>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_schema_versions
-
- start(I, Cassandra.describe_snitch_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_snitch
-
- start(I, Cassandra.describe_splits_args, AsyncMethodCallback<List<String>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits
-
- start(I, Cassandra.describe_splits_ex_args, AsyncMethodCallback<List<CfSplit>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits_ex
-
- start(I, Cassandra.describe_token_map_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_token_map
-
- start(I, Cassandra.describe_version_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_version
-
- start(I, Cassandra.execute_cql3_query_args, AsyncMethodCallback<CqlResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql3_query
-
- start(I, Cassandra.execute_cql_query_args, AsyncMethodCallback<CqlResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql_query
-
- start(I, Cassandra.execute_prepared_cql3_query_args, AsyncMethodCallback<CqlResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql3_query
-
- start(I, Cassandra.execute_prepared_cql_query_args, AsyncMethodCallback<CqlResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql_query
-
- start(I, Cassandra.get_args, AsyncMethodCallback<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- start(I, Cassandra.get_count_args, AsyncMethodCallback<Integer>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- start(I, Cassandra.get_indexed_slices_args, AsyncMethodCallback<List<KeySlice>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- start(I, Cassandra.get_multi_slice_args, AsyncMethodCallback<List<ColumnOrSuperColumn>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_multi_slice
-
- start(I, Cassandra.get_paged_slice_args, AsyncMethodCallback<List<KeySlice>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- start(I, Cassandra.get_range_slices_args, AsyncMethodCallback<List<KeySlice>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- start(I, Cassandra.get_slice_args, AsyncMethodCallback<List<ColumnOrSuperColumn>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- start(I, Cassandra.insert_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- start(I, Cassandra.login_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.login
-
- start(I, Cassandra.multiget_count_args, AsyncMethodCallback<Map<ByteBuffer, Integer>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_count
-
- start(I, Cassandra.multiget_slice_args, AsyncMethodCallback<Map<ByteBuffer, List<ColumnOrSuperColumn>>>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_slice
-
- start(I, Cassandra.prepare_cql3_query_args, AsyncMethodCallback<CqlPreparedResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql3_query
-
- start(I, Cassandra.prepare_cql_query_args, AsyncMethodCallback<CqlPreparedResult>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql_query
-
- start(I, Cassandra.remove_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- start(I, Cassandra.remove_counter_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- start(I, Cassandra.set_cql_version_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- start(I, Cassandra.set_keyspace_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- start(I, Cassandra.system_add_column_family_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- start(I, Cassandra.system_add_keyspace_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- start(I, Cassandra.system_drop_column_family_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- start(I, Cassandra.system_drop_keyspace_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- start(I, Cassandra.system_update_column_family_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- start(I, Cassandra.system_update_keyspace_args, AsyncMethodCallback<String>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- start(I, Cassandra.trace_next_query_args, AsyncMethodCallback<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.trace_next_query
-
- start(I, Cassandra.truncate_args, AsyncMethodCallback<Void>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.truncate
-
- start - Variable in class org.apache.cassandra.thrift.ColumnSlice
-
- start - Variable in class org.apache.cassandra.thrift.SliceRange
-
- start() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- start() - Method in class org.apache.cassandra.transport.Server
-
- start() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
Start an operation against this OpOrder.
- start_column - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- start_key - Variable in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- start_key - Variable in class org.apache.cassandra.thrift.KeyRange
-
- start_native_transport - Variable in class org.apache.cassandra.config.Config
-
- start_rpc - Variable in class org.apache.cassandra.config.Config
-
- start_token - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- start_token - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- start_token - Variable in class org.apache.cassandra.thrift.CfSplit
-
- start_token - Variable in class org.apache.cassandra.thrift.KeyRange
-
- start_token - Variable in class org.apache.cassandra.thrift.TokenRange
-
- startBatchlogReplay() - Method in class org.apache.cassandra.db.BatchlogManager
-
- startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- startCompaction(ColumnFamilyStore, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Write compaction log, except columfamilies under system keyspace.
- started() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
report event on the size of the compaction.
- startGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startKey() - Method in class org.apache.cassandra.db.DataRange
-
- startNativeTransport() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- startNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startOf(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- startParentRepair(UUID, String, String[], Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- startRepairs(UUID, UUID, String, String[], Range<Token>, Iterable<InetAddress>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- startRpc() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.LocalSyncTask
-
Starts sending/receiving our list of differences to/from the remote endpoint: creates a callback
that will be called out of band once the streams complete.
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.RemoteSyncTask
-
- startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.SyncTask
-
- startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
-
- startTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- startup() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Performs any extra initialization required
- startup() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- StartupCheck - Interface in org.apache.cassandra.service
-
A test to determine if the system is in a valid state to start up.
- startupChecks - Variable in class org.apache.cassandra.service.CassandraDaemon
-
- StartupChecks - Class in org.apache.cassandra.service
-
Verifies that the system and environment is in a fit state to be started.
- StartupChecks() - Constructor for class org.apache.cassandra.service.StartupChecks
-
- StartupException - Exception in org.apache.cassandra.exceptions
-
An exception thrown during system startup, indicating the environment or system
is not in a valid state to startup.
- StartupException(int, String) - Constructor for exception org.apache.cassandra.exceptions.StartupException
-
- StartupException(int, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.StartupException
-
- StartupMessage - Class in org.apache.cassandra.transport.messages
-
The initial message of the protocol.
- StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
-
- stat - Variable in class org.apache.cassandra.repair.SyncTask
-
- state(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
- State() - Constructor for class org.apache.cassandra.service.ClientWarn.State
-
- 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
-
- state() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
- stateFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- statement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- StatementRestrictions - Class in org.apache.cassandra.cql3.restrictions
-
The restrictions corresponding to the relations specified on the where-clause of CQL query.
- StatementRestrictions(CFMetaData, List<Relation>, VariableSpecifications, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
- states() - Method in class org.apache.cassandra.gms.EndpointState
-
- stateType - Variable in class org.apache.cassandra.cql3.functions.UDAggregate
-
- stateType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
-
- STATIC_MARKER - Static variable in class org.apache.cassandra.db.marshal.CompositeType
-
- staticBuilder(CompositeType) - Static method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- staticColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- staticDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- staticPrefix() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- staticPrefix() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
The prefix to use for static columns.
- staticPrefix() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- STATS - Static variable in class org.apache.cassandra.io.sstable.Component
-
- stats - Variable in class org.apache.cassandra.repair.RepairResult
-
- StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- statsMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
- StatsMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata that always stay on heap.
- StatsMetadata(EstimatedHistogram, EstimatedHistogram, ReplayPosition, ReplayPosition, long, long, int, double, StreamingHistogram, int, List<ByteBuffer>, List<ByteBuffer>, boolean, long) - Constructor for class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- StatsMetadata.StatsMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
- StatsMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- Status - Class in org.apache.cassandra.tools.nodetool
-
- Status() - Constructor for class org.apache.cassandra.tools.nodetool.Status
-
- status - Variable in class org.apache.cassandra.transport.Event.StatusChange
-
- STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_BOOTSTRAPPING_REPLACE - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- StatusBackup - Class in org.apache.cassandra.tools.nodetool
-
- StatusBackup() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBackup
-
- StatusBinary - Class in org.apache.cassandra.tools.nodetool
-
- StatusBinary() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBinary
-
- statusCode - Variable in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
- StatusGossip - Class in org.apache.cassandra.tools.nodetool
-
- StatusGossip() - Constructor for class org.apache.cassandra.tools.nodetool.StatusGossip
-
- StatusHandoff - Class in org.apache.cassandra.tools.nodetool
-
- StatusHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.StatusHandoff
-
- StatusLogger - Class in org.apache.cassandra.utils
-
- StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
-
- StatusThrift - Class in org.apache.cassandra.tools.nodetool
-
- StatusThrift() - Constructor for class org.apache.cassandra.tools.nodetool.StatusThrift
-
- 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 - Class in org.apache.cassandra.tools.nodetool
-
- Stop() - Constructor for class org.apache.cassandra.tools.nodetool.Stop
-
- stop() - Method in class org.apache.cassandra.tracing.TraceState
-
- stop() - Method in class org.apache.cassandra.transport.Server
-
- stopById(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopCassandraDaemon() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopClient() - Method in class org.apache.cassandra.service.StorageService
-
- stopCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- stopCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Stop all running compaction-like tasks having the provided type
.
- stopCompactionById(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- stopCompactionById(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Stop an individual running compaction using the compactionId.
- stopDaemon() - Method in class org.apache.cassandra.service.StorageService
-
- stopDaemon() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- StopDaemon - Class in org.apache.cassandra.tools.nodetool
-
- StopDaemon() - Constructor for class org.apache.cassandra.tools.nodetool.StopDaemon
-
- stopGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopKey() - Method in class org.apache.cassandra.db.DataRange
-
- stopNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopSession() - Method in class org.apache.cassandra.tracing.Tracing
-
Stop the session and record its complete.
- stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopTransports() - Method in class org.apache.cassandra.service.StorageService
-
- stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
Stops CL, for testing purposes.
- storage_port - Variable in class org.apache.cassandra.config.Config
-
- StorageHelper - Class in org.apache.cassandra.hadoop.pig
-
Deprecated.
- StorageHelper() - Constructor for class org.apache.cassandra.hadoop.pig.StorageHelper
-
Deprecated.
- 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.CassandraStorage
-
Deprecated.
- storeSignature - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
Deprecated.
- strategy_class - Variable in class org.apache.cassandra.thrift.KsDef
-
- strategy_options - Variable in class org.apache.cassandra.thrift.KsDef
-
- strategyClass - Variable in class org.apache.cassandra.config.KSMetaData
-
- strategyOptions - Variable in class org.apache.cassandra.config.KSMetaData
-
- stream() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream(Set<InetAddress>, StreamEventHandler...) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- stream - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.BulkRecordWriter
-
Deprecated.
- STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
-
- stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- StreamConnectionFactory - Interface in org.apache.cassandra.streaming
-
Interface that creates connection used by streaming.
- StreamCoordinator - Class in org.apache.cassandra.streaming
-
StreamCoordinator
is a helper class that abstracts away maintaining multiple
StreamSession and ProgressInfo instances per peer.
- StreamCoordinator(int, boolean, boolean, StreamConnectionFactory) - Constructor for class org.apache.cassandra.streaming.StreamCoordinator
-
- StreamEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent(StreamEvent.Type, UUID) - Constructor for class org.apache.cassandra.streaming.StreamEvent
-
- StreamEvent.ProgressEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionCompleteEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionPreparedEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.Type - Enum in org.apache.cassandra.streaming
-
- StreamEventHandler - Interface in org.apache.cassandra.streaming
-
- StreamEventJMXNotifier - Class in org.apache.cassandra.streaming.management
-
- StreamEventJMXNotifier() - Constructor for class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
-
- StreamException - Exception in org.apache.cassandra.streaming
-
- StreamException(StreamState, String) - Constructor for exception org.apache.cassandra.streaming.StreamException
-
- StreamException(StreamState, String, Throwable) - Constructor for exception org.apache.cassandra.streaming.StreamException
-
- streamId - Variable in class org.apache.cassandra.transport.Frame.Header
-
- streaming_socket_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- StreamingHistogram - Class in org.apache.cassandra.utils
-
Histogram that can be constructed from streaming of data.
- StreamingHistogram(int) - Constructor for class org.apache.cassandra.utils.StreamingHistogram
-
Creates a new histogram with max bin size of maxBinSize
- StreamingHistogram.StreamingHistogramSerializer - Class in org.apache.cassandra.utils
-
- StreamingHistogramSerializer() - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- StreamingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for streaming.
- StreamingMetrics(InetAddress) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
-
- StreamingRepairTask - Class in org.apache.cassandra.repair
-
StreamingRepairTask performs data streaming between two remote replica which neither is not repair coordinator.
- StreamingRepairTask(RepairJobDesc, SyncRequest, long) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
-
- StreamInitMessage - Class in org.apache.cassandra.streaming.messages
-
StreamInitMessage is first sent from the node where
StreamSession
is started,
to initiate corresponding
StreamSession
on the other side.
- StreamInitMessage(InetAddress, int, UUID, String, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- StreamLockfile - Class in org.apache.cassandra.streaming
-
Encapsulates the behavior for 'locking' any streamed sttables to a node.
- StreamLockfile(File, UUID) - Constructor for class org.apache.cassandra.streaming.StreamLockfile
-
- StreamLockfile(File) - Constructor for class org.apache.cassandra.streaming.StreamLockfile
-
- StreamManager - Class in org.apache.cassandra.streaming
-
StreamManager manages currently running
StreamResultFuture
s and provides status of all operation invoked.
- StreamManager() - Constructor for class org.apache.cassandra.streaming.StreamManager
-
- StreamManager.StreamRateLimiter - Class in org.apache.cassandra.streaming
-
- StreamManagerMBean - Interface in org.apache.cassandra.streaming
-
- StreamMessage - Class in org.apache.cassandra.streaming.messages
-
StreamMessage is an abstract base class that every messages in streaming protocol inherit.
- StreamMessage(StreamMessage.Type) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessage
-
- StreamMessage.Serializer<V extends StreamMessage> - Interface in org.apache.cassandra.streaming.messages
-
StreamMessage serializer
- StreamMessage.Type - Enum in org.apache.cassandra.streaming.messages
-
StreamMessage types
- StreamPlan - Class in org.apache.cassandra.streaming
-
StreamPlan
is a helper class that builds StreamOperation of given configuration.
- StreamPlan(String) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
Start building stream plan.
- StreamPlan(String, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
- StreamPlan(String, long, int, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
- StreamRateLimiter(InetAddress) - Constructor for class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
-
- StreamReader - Class in org.apache.cassandra.streaming
-
StreamReader reads from stream and writes to SSTable.
- StreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamReader
-
- StreamReceiveTask - Class in org.apache.cassandra.streaming
-
Task that manages receiving files for the session for certain ColumnFamily.
- StreamReceiveTask(StreamSession, UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
-
- StreamRequest - Class in org.apache.cassandra.streaming
-
- StreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Constructor for class org.apache.cassandra.streaming.StreamRequest
-
- StreamRequest.StreamRequestSerializer - Class in org.apache.cassandra.streaming
-
- StreamRequestSerializer() - Constructor for class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- StreamResultFuture - Class in org.apache.cassandra.streaming
-
A future on the result (
StreamState
) of a streaming plan.
- StreamSession - Class in org.apache.cassandra.streaming
-
Handles the streaming a one or more section of one of more sstables to and from a specific
remote node.
- StreamSession(InetAddress, InetAddress, StreamConnectionFactory, int, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamSession
-
Create new streaming session with the peer.
- StreamSession.SSTableStreamingSections - Class in org.apache.cassandra.streaming
-
- StreamSession.State - Enum in org.apache.cassandra.streaming
-
- StreamState - Class in org.apache.cassandra.streaming
-
Current snapshot of streaming progress.
- StreamState(UUID, String, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
-
- StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- StreamStateStore - Class in org.apache.cassandra.dht
-
Store and update available ranges (data already received) to system keyspace.
- StreamStateStore() - Constructor for class org.apache.cassandra.dht.StreamStateStore
-
- StreamSummary - Class in org.apache.cassandra.streaming
-
Summary of streaming.
- StreamSummary(UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamSummary
-
- StreamSummary.StreamSummarySerializer - Class in org.apache.cassandra.streaming
-
- StreamSummaryCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamSummaryCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- StreamSummarySerializer() - Constructor for class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- StreamTask - Class in org.apache.cassandra.streaming
-
StreamTask is an abstraction of the streaming task performed over specific ColumnFamily.
- StreamTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTask
-
- StreamTransferTask - Class in org.apache.cassandra.streaming
-
StreamTransferTask sends sections of SSTable files in certain ColumnFamily.
- StreamTransferTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
-
- StreamWriter - Class in org.apache.cassandra.streaming
-
StreamWriter writes given section of the SSTable to given channel.
- StreamWriter(SSTableReader, Collection<Pair<Long, Long>>, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamWriter
-
- strictlyWrapsAround(T, T) - Static method in class org.apache.cassandra.dht.AbstractBounds
-
Whether left
and right
forms a wrapping interval, that is if unwrapping wouldn't be a no-op.
- 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.
- stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyCollectionsParameters(Map<ByteBuffer, ? extends CollectionType>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- stringifyTypeParameters(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyTypeParameters(List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyUserTypeParameters(String, ByteBuffer, List<ByteBuffer>, List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- StringSerializer() - Constructor for class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- StringToken(String) - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner.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
-
- subcomparator_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
Task Submission / Creation / Objects
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
-
- submitAntiCompaction(ColumnFamilyStore, Collection<Range<Token>>, Refs<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Call this whenever a compaction might be needed on the given columnfamily.
- submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitHint(Mutation, InetAddress, AbstractWriteResponseHandler<IMutation>) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Is not scheduled, because it is performing disjoint work from sstable compaction.
- submitMaximal(ColumnFamilyStore, int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitRepairSession(UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, long, ListeningExecutorService, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Requests repairs for the given keyspace and column families.
- submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitValidation(ColumnFamilyStore, Validator) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Does not mutate data, so is not scheduled.
- submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- subName(Composite) - Static method in class org.apache.cassandra.db.SuperColumns
-
- SubPool(long, float) - Constructor for class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
-
- subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- subSet(V, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- Substracter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
-
- Substraction(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Substraction
-
- subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- subtractAll(Collection<Range<T>>) - Method in class org.apache.cassandra.dht.Range
-
- subtype(int) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
-
- subtype(int) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
-
- subtype(int) - Method in class org.apache.cassandra.db.composites.CompoundCType
-
- subtype(int) - Method in interface org.apache.cassandra.db.composites.CType
-
Gets a subtype of this CType.
- subtype(int) - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- success - Variable in class org.apache.cassandra.db.TruncateResponse
-
- success - Variable in class org.apache.cassandra.repair.messages.SyncComplete
-
true if sync success, false otherwise
- success - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
true if validation success, false otherwise
- success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- success - Variable in class org.apache.cassandra.thrift.CASResult
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- success - Variable in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- successfulParentRepair(UUID, Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- successfulRanges - Variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
-
Successfully repaired ranges.
- successfulRepairJob(UUID, String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
-
Calculates estimated number of points in interval [-inf,b].
- sumArrays(int[], int[]) - Static method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- sumFunctionForByte - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for byte values (tinyint).
- sumFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for counter column values.
- sumFunctionForDecimal - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for decimal values.
- sumFunctionForDouble - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for double values.
- sumFunctionForFloat - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for float values.
- sumFunctionForInt32 - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for int32 values.
- sumFunctionForLong - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for long values.
- sumFunctionForShort - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for short values (smallint).
- sumFunctionForVarint - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
The SUM function for varint values.
- summaries - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Summaries of streaming out
- SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
-
- summaryCount - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
-
- super_column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- super_column - Variable in class org.apache.cassandra.thrift.ColumnParent
-
- super_column - Variable in class org.apache.cassandra.thrift.ColumnPath
-
- super_column - Variable in class org.apache.cassandra.thrift.Deletion
-
- SuperColumn - Class in org.apache.cassandra.thrift
-
A named list of columns.
- SuperColumn() - Constructor for class org.apache.cassandra.thrift.SuperColumn
-
- SuperColumn(ByteBuffer, List<Column>) - Constructor for class org.apache.cassandra.thrift.SuperColumn
-
- SuperColumn(SuperColumn) - Constructor for class org.apache.cassandra.thrift.SuperColumn
-
Performs a deep copy on other.
- SuperColumn._Fields - Enum in org.apache.cassandra.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- SuperColumns - Class in org.apache.cassandra.db
-
- SuperColumns() - Constructor for class org.apache.cassandra.db.SuperColumns
-
- supersedes(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- supersedes(RangeTombstone, Comparator<Composite>) - Method in class org.apache.cassandra.db.RangeTombstone
-
This tombstone supersedes another one if it is more recent and cover a
bigger range than rt.
- SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
- supportCollections() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- supportCollections() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
Whether or not this type layout support collections.
- supportCollections() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
-
- supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- SupportedMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
-
- supportedOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- supportedOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Set of options supported by CREATE ROLE and ALTER ROLE queries.
- supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- supportExitOnOutOfMemory(String) - Static method in class org.apache.cassandra.utils.JavaUtils
-
Checks if the specified JRE support ExitOnOutOfMemory and CrashOnOutOfMemory.
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supports(BufferType) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
Checks if the given buffer would be supported by the compressor.
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supports(BufferType) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- SUPPORTS_GLOBAL_PREPARE_FLAG_VERSION - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- supportsDirectChecksum() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- supportsFreezing() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
-
- supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns true if the index supports lookups for the given operator, false otherwise.
- switchMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- switchMemtable(boolean, Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
Switch the current memtable.
- switchMemtableIfCurrent(Memtable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Switches the memtable iff the live memtable is the one provided
- switchWriter(SSTableWriter) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- sync(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Forces a disk flush on the commit log files that need it.
- sync() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Deprecated.
- 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
-
- sync(FileDescriptor) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- sync(RandomAccessFile) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- sync(FileOutputStream) - Static method in class org.apache.cassandra.utils.SyncUtil
-
- syncComplete - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- SyncComplete - Class in org.apache.cassandra.repair.messages
-
- SyncComplete(RepairJobDesc, NodePair, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- SyncComplete(RepairJobDesc, InetAddress, InetAddress, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- syncComplete(boolean) - Method in class org.apache.cassandra.repair.RemoteSyncTask
-
- syncComplete(RepairJobDesc, NodePair, boolean) - Method in class org.apache.cassandra.repair.RepairSession
-
Notify this session that sync completed/failed with given NodePair
.
- syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncNeeded - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- SyncRequest - Class in org.apache.cassandra.repair.messages
-
Body part of SYNC_REQUEST repair message.
- SyncRequest(RepairJobDesc, InetAddress, InetAddress, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
-
- SyncRequest.SyncRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- SyncRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- SyncStat - Class in org.apache.cassandra.repair
-
Statistics about synchronizing two replica
- SyncStat(NodePair, long) - Constructor for class org.apache.cassandra.repair.SyncStat
-
- SyncTask - Class in org.apache.cassandra.repair
-
SyncTask will calculate the difference of MerkleTree between two nodes
and perform necessary operation to repair replica.
- SyncTask(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.SyncTask
-
- SyncUtil - Class in org.apache.cassandra.utils
-
- SyncUtil() - Constructor for class org.apache.cassandra.utils.SyncUtil
-
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error occurs.
- syntaxError(BaseRecognizer, String) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error with a specified message occurs.
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error occurs.
- syntaxError(BaseRecognizer, String) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error with a specified message occurs.
- SyntaxException - Exception in org.apache.cassandra.exceptions
-
- SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
-
- 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, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_add_column_family(CfDef, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_add_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_add_column_family(CfDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
adds a column family.
- system_add_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_add_column_family
-
- system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_add_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- system_add_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- system_add_column_family_args(Cassandra.system_add_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
Performs a deep copy on other.
- system_add_column_family_call(CfDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
-
- system_add_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- system_add_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- system_add_column_family_result(Cassandra.system_add_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
Performs a deep copy on other.
- system_add_keyspace(KsDef, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_add_keyspace(KsDef, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_add_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_add_keyspace(KsDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
adds a keyspace and any column families that are part of it.
- system_add_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_add_keyspace
-
- system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_add_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- system_add_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- system_add_keyspace_args(Cassandra.system_add_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
Performs a deep copy on other.
- system_add_keyspace_call(KsDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
-
- system_add_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- system_add_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- system_add_keyspace_result(Cassandra.system_add_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
Performs a deep copy on other.
- system_drop_column_family(String, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_drop_column_family(String, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_drop_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_drop_column_family(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
drops a column family.
- system_drop_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_column_family
-
- system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- system_drop_column_family_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- system_drop_column_family_args(Cassandra.system_drop_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
Performs a deep copy on other.
- system_drop_column_family_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
-
- system_drop_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- system_drop_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- system_drop_column_family_result(Cassandra.system_drop_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
Performs a deep copy on other.
- system_drop_keyspace(String, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_drop_keyspace(String, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_drop_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_drop_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
drops a keyspace and any column families that are part of it.
- system_drop_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_keyspace
-
- system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_drop_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- system_drop_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- system_drop_keyspace_args(Cassandra.system_drop_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
Performs a deep copy on other.
- system_drop_keyspace_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
-
- system_drop_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- system_drop_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- system_drop_keyspace_result(Cassandra.system_drop_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
Performs a deep copy on other.
- system_update_column_family(CfDef, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_update_column_family(CfDef, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_update_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_update_column_family(CfDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
updates properties of a column family.
- system_update_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_update_column_family
-
- system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_update_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- system_update_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- system_update_column_family_args(Cassandra.system_update_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
Performs a deep copy on other.
- system_update_column_family_call(CfDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
-
- system_update_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- system_update_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- system_update_column_family_result(Cassandra.system_update_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
Performs a deep copy on other.
- system_update_keyspace(KsDef, AsyncMethodCallback) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- system_update_keyspace(KsDef, AsyncMethodCallback) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
-
- system_update_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- system_update_keyspace(KsDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
updates properties of a keyspace.
- system_update_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_update_keyspace
-
- system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
update an existing keyspace, but do not allow column family modifications.
- system_update_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- system_update_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- system_update_keyspace_args(Cassandra.system_update_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
Performs a deep copy on other.
- system_update_keyspace_call(KsDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
-
- system_update_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- system_update_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- system_update_keyspace_result(Cassandra.system_update_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
Performs a deep copy on other.
- SYSTEM_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- SYSTEM_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
-
- SystemDistributedKeyspace - Class in org.apache.cassandra.repair
-
- SystemDistributedKeyspace() - Constructor for class org.apache.cassandra.repair.SystemDistributedKeyspace
-
- SystemKeyspace - Class in org.apache.cassandra.db
-
- SystemKeyspace() - Constructor for class org.apache.cassandra.db.SystemKeyspace
-
- SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
-
- SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- validate() - Method in class org.apache.cassandra.auth.RoleOptions
-
Validate the contents of the options in two ways:
- Ensure that only a subset of the options supported by the configured IRoleManager are set
- Validate the type of any option values present.
- validate() - Method in class org.apache.cassandra.config.CFMetaData
-
- validate() - Method in class org.apache.cassandra.config.KSMetaData
-
- validate(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform additional validation required by the statment.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- validate() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- validate() - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
-
- validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- validate(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- validate(Composite) - Method in interface org.apache.cassandra.db.composites.CType
-
Validates a composite.
- validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- validate(Cell) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- validate(Cell) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- validate(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- validate(IndexExpression) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- validate() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- validate(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
- validate(String) - Static method in class org.apache.cassandra.io.sstable.format.Version
-
- validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- validate() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.AsciiSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ByteSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ShortSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TupleSerializer
-
- validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UserTypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UTF8Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- validate() - Method in exception org.apache.cassandra.thrift.AuthenticationException
-
- validate() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- validate() - Method in exception org.apache.cassandra.thrift.AuthorizationException
-
- validate() - Method in class org.apache.cassandra.thrift.CASResult
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.add_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.add_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.cas_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_multi_slice_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- validate() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- validate() - Method in class org.apache.cassandra.thrift.CfDef
-
- validate() - Method in class org.apache.cassandra.thrift.CfSplit
-
- validate() - Method in class org.apache.cassandra.thrift.Column
-
- validate() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- validate() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- validate() - Method in class org.apache.cassandra.thrift.ColumnParent
-
- validate() - Method in class org.apache.cassandra.thrift.ColumnPath
-
- validate() - Method in class org.apache.cassandra.thrift.ColumnSlice
-
- validate() - Method in class org.apache.cassandra.thrift.CounterColumn
-
- validate() - Method in class org.apache.cassandra.thrift.CounterSuperColumn
-
- validate() - Method in class org.apache.cassandra.thrift.CqlMetadata
-
- validate() - Method in class org.apache.cassandra.thrift.CqlPreparedResult
-
- validate() - Method in class org.apache.cassandra.thrift.CqlResult
-
- validate() - Method in class org.apache.cassandra.thrift.CqlRow
-
- validate() - Method in class org.apache.cassandra.thrift.Deletion
-
- validate() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- validate() - Method in class org.apache.cassandra.thrift.IndexClause
-
Deprecated.
- validate() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- validate() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
-
- validate() - Method in class org.apache.cassandra.thrift.KeyCount
-
- validate() - Method in class org.apache.cassandra.thrift.KeyRange
-
- validate() - Method in class org.apache.cassandra.thrift.KeySlice
-
- validate() - Method in class org.apache.cassandra.thrift.KsDef
-
- validate() - Method in class org.apache.cassandra.thrift.MultiSliceRequest
-
- validate() - Method in class org.apache.cassandra.thrift.Mutation
-
- validate() - Method in exception org.apache.cassandra.thrift.NotFoundException
-
- validate() - Method in exception org.apache.cassandra.thrift.SchemaDisagreementException
-
- validate() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- validate() - Method in class org.apache.cassandra.thrift.SliceRange
-
- validate() - Method in class org.apache.cassandra.thrift.SuperColumn
-
- validate() - Method in exception org.apache.cassandra.thrift.TimedOutException
-
- validate() - Method in class org.apache.cassandra.thrift.TokenRange
-
- validate() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- validate() - Method in exception org.apache.cassandra.thrift.UnavailableException
-
- validateCellName(CellName, CellNameType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateCellNames(Iterable<CellName>, CellNameType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Validate cell value.
- validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- validateClusteringRestrictions(boolean) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Validates whether or not restrictions are allowed for execution when secondary index is not used.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative validation function used by CollectionsType in conjunction with CompositeType.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validateColumnData(CFMetaData, ByteBuffer, ByteBuffer, Column) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
Validates the data part of the column (everything in the column object but the name, which is assumed to be valid)
- validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnOrSuperColumn(CFMetaData, ByteBuffer, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnParent(CFMetaData, ColumnParent) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnPath(CFMetaData, ColumnPath) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
validates all parts of the path to the column, including the column name
- validateCompactionOptions(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Like getComparator, but validates that @param i does not exceed the defined range
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- validateCompatility(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateComposite(Composite, CType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraRoleManager
-
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Validates configuration of IAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Validates configuration of IAuthorizer implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Validates configuration of IInternodeAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Hook to perform validation of an implementation's configuration (if supported).
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
Deprecated.
- validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.AbstractCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferCounterCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferDeletedCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferExpiringCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeCounterCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeDeletedCell
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeExpiringCell
-
- validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.RangeTombstone
-
- validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForCasCommit(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
-
- validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.MapSerializer
-
- validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.SetSerializer
-
- validateForRead(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForWrite(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateIndexSearchersForQuery(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Validates an union of expression index types.
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspace(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotSystem(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotYetExisting(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateLogin() - Method in class org.apache.cassandra.service.ClientState
-
- validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
-
- validateMutation(CFMetaData, ByteBuffer, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateName(CFMetaData) - Method in class org.apache.cassandra.db.AbstractCell
-
- validateNewMessage(Message.Type, int, int) - Method in class org.apache.cassandra.transport.ServerConnection
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- validateOptions() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Validates the index_options passed in the ColumnDef
- validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- validatePartitioner(AbstractBounds<?>) - Static method in class org.apache.cassandra.net.MessagingService
-
- validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateReallocation(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateRowLevelIndexes(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateSlices(ColumnSlice[], CellNameType, boolean) - Static method in class org.apache.cassandra.db.filter.ColumnSlice
-
Validates that the provided slice array contains only non-overlapped slices valid for a query reversed
or not on a table using comparator
.
- validateWhereClauseForConditions() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
-
- validateWhereClauseForConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
If there are conditions on the statement, this is called after the where clause and conditions have been
processed to check that they are compatible.
- validation_class - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- ValidationComplete - Class in org.apache.cassandra.repair.messages
-
ValidationComplete message is sent when validation compaction completed successfully.
- ValidationComplete(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- ValidationComplete(RepairJobDesc, MerkleTree) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
-
- validationComplete(RepairJobDesc, InetAddress, MerkleTree) - Method in class org.apache.cassandra.repair.RepairSession
-
Receive merkle tree response or failed response from endpoint
for current repair job.
- ValidationMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata component used only for validating SSTable.
- ValidationMetadata(String, double) - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
-
- ValidationMetadata.ValidationMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
-
- ValidationMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
-
- ValidationRequest - Class in org.apache.cassandra.repair.messages
-
ValidationRequest
- ValidationRequest(RepairJobDesc, int) - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest
-
- ValidationRequest.ValidationRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- ValidationRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- ValidationTask - Class in org.apache.cassandra.repair
-
- ValidationTask(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.ValidationTask
-
- validator - Variable in class org.apache.cassandra.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
-
- Validator(RepairJobDesc, InetAddress, int, boolean) - Constructor for class org.apache.cassandra.repair.Validator
-
- validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- value - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
-
- Value(List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Lists.Value
-
- Value(Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
-
- value - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
-
- Value(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
-
- Value(ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.Tuples.Value
-
- value() - Method in class org.apache.cassandra.db.AbstractNativeCell
-
- value - Variable in class org.apache.cassandra.db.BufferCell
-
- value() - Method in class org.apache.cassandra.db.BufferCell
-
- value() - Method in interface org.apache.cassandra.db.Cell
-
- value - Variable in class org.apache.cassandra.db.IndexExpression
-
- value - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
-
- value - Variable in class org.apache.cassandra.gms.VersionedValue
-
- value - Variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader.Column
-
Deprecated.
- value - Variable in class org.apache.cassandra.thrift.Column
-
- value - Variable in class org.apache.cassandra.thrift.CounterColumn
-
- value - Variable in class org.apache.cassandra.thrift.IndexExpression
-
- value() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- value - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- value_types - Variable in class org.apache.cassandra.thrift.CqlMetadata
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.ListType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.MapType
-
- valueComparator() - Method in class org.apache.cassandra.db.marshal.SetType
-
- valueCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
-
- valueFactory - Variable in class org.apache.cassandra.service.StorageService
-
- valueOf(String) - Static method in enum org.apache.cassandra.auth.IRoleManager.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cache.CachingOptions.KeyCache.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cache.CachingOptions.RowCache.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.MemtableAllocationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.IndexType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Attributes.ExpirationDateOverflowPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.ModificationStatement.StatementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnSerializer.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.composites.Composite.EOC
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.context.CounterContext.Relationship
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.Directories.FileAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.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.CassandraStorage.MarshallerType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.compress.BufferType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.Descriptor.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.metrics.ColumnFamilyMetrics.Sampler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CASResult._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.add_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.cas_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_local_ring_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_token_map_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_cql_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_multi_slice_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_paged_slice_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_counter_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_cql_version_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.trace_next_query_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CfSplit._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Column._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnSlice._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.ConsistencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CounterColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CounterSuperColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CqlMetadata._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CqlPreparedResult._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CqlResult._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CqlResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.CqlRow._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.EndpointDetails._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.MultiSliceRequest._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.SchemaDisagreementException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.TriggerDef._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.tracing.TraceState.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Target
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.AsymmetricOrdering.Op
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.cassandra.auth.IRoleManager.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.auth.Permission
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cache.CachingOptions.KeyCache.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cache.CachingOptions.RowCache.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.CommitFailurePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.DiskFailurePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.MemtableAllocationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.IndexType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Attributes.ExpirationDateOverflowPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
-
- values - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
-
- values(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
-
- values(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
-
- values() - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.ModificationStatement.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ColumnSerializer.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.composites.Composite.EOC
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.context.CounterContext.Relationship
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.Directories.FileAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.RowPosition.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.WriteType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.gms.ApplicationState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.hadoop.pig.CassandraStorage.MarshallerType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.compress.BufferType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.Descriptor.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
-
- values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
-
- values() - Static method in enum org.apache.cassandra.metrics.ColumnFamilyMetrics.Sampler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.repair.RepairParallelism
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.serializers.MapSerializer
-
- values() - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
-
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.AuthenticationRequest._Fields
-
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.AuthorizationException._Fields
-
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.CASResult._Fields
-
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.Cassandra.add_args._Fields
-
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.Cassandra.add_result._Fields
-
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.Cassandra.atomic_batch_mutate_args._Fields
-
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.Cassandra.atomic_batch_mutate_result._Fields
-
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.Cassandra.batch_mutate_args._Fields
-
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.Cassandra.batch_mutate_result._Fields
-
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.Cassandra.cas_args._Fields
-
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.Cassandra.cas_result._Fields
-
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.Cassandra.describe_cluster_name_args._Fields
-
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.Cassandra.describe_cluster_name_result._Fields
-
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.Cassandra.describe_keyspace_args._Fields
-
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.Cassandra.describe_keyspace_result._Fields
-
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.Cassandra.describe_keyspaces_args._Fields
-
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.Cassandra.describe_keyspaces_result._Fields
-
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.Cassandra.describe_local_ring_args._Fields
-
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.Cassandra.describe_local_ring_result._Fields
-
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.Cassandra.describe_partitioner_args._Fields
-
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.Cassandra.describe_partitioner_result._Fields
-
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.Cassandra.describe_ring_args._Fields
-
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.Cassandra.describe_ring_result._Fields
-
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.Cassandra.describe_schema_versions_args._Fields
-
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.Cassandra.describe_schema_versions_result._Fields
-
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.Cassandra.describe_snitch_args._Fields
-
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.Cassandra.describe_snitch_result._Fields
-
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.Cassandra.describe_splits_args._Fields
-
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.Cassandra.describe_splits_ex_args._Fields
-
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.Cassandra.describe_splits_ex_result._Fields
-
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.Cassandra.describe_splits_result._Fields
-
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.Cassandra.describe_token_map_args._Fields
-
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.Cassandra.describe_token_map_result._Fields
-
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.Cassandra.describe_version_args._Fields
-
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.Cassandra.describe_version_result._Fields
-
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.Cassandra.execute_cql3_query_args._Fields
-
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.Cassandra.execute_cql3_query_result._Fields
-
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.Cassandra.execute_cql_query_args._Fields
-
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.Cassandra.execute_cql_query_result._Fields
-
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.Cassandra.execute_prepared_cql3_query_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- values() - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result._Fields
-
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.Cassandra.execute_prepared_cql_query_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- values() - Static method in enum org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result._Fields
-
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.Cassandra.get_args._Fields
-
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.Cassandra.get_count_args._Fields
-
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.Cassandra.get_count_result._Fields
-
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.Cassandra.get_indexed_slices_args._Fields
-
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.Cassandra.get_indexed_slices_result._Fields
-
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.Cassandra.get_multi_slice_args._Fields
-
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.Cassandra.get_multi_slice_result._Fields
-
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.Cassandra.get_paged_slice_args._Fields
-
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.Cassandra.get_paged_slice_result._Fields
-
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.Cassandra.get_range_slices_args._Fields
-
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.Cassandra.get_range_slices_result._Fields
-
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.Cassandra.get_result._Fields
-
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.Cassandra.get_slice_args._Fields
-
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.Cassandra.get_slice_result._Fields
-
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.Cassandra.insert_args._Fields
-
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.Cassandra.insert_result._Fields
-
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.Cassandra.login_args._Fields
-
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.Cassandra.login_result._Fields
-
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.Cassandra.multiget_count_args._Fields
-
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.Cassandra.multiget_count_result._Fields
-
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.Cassandra.multiget_slice_args._Fields
-
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.Cassandra.multiget_slice_result._Fields
-
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.Cassandra.prepare_cql3_query_args._Fields
-
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.Cassandra.prepare_cql3_query_result._Fields
-
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.Cassandra.prepare_cql_query_args._Fields
-
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.Cassandra.prepare_cql_query_result._Fields
-
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.Cassandra.remove_args._Fields
-
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.Cassandra.remove_counter_args._Fields
-
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.Cassandra.remove_counter_result._Fields
-
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.Cassandra.remove_result._Fields
-
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.Cassandra.set_cql_version_args._Fields
-
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.Cassandra.set_cql_version_result._Fields
-
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.Cassandra.set_keyspace_args._Fields
-
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.Cassandra.set_keyspace_result._Fields
-
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.Cassandra.system_add_column_family_args._Fields
-
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.Cassandra.system_add_column_family_result._Fields
-
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.Cassandra.system_add_keyspace_args._Fields
-
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.Cassandra.system_add_keyspace_result._Fields
-
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.Cassandra.system_drop_column_family_args._Fields
-
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.Cassandra.system_drop_column_family_result._Fields
-
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.Cassandra.system_drop_keyspace_args._Fields
-
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.Cassandra.system_drop_keyspace_result._Fields
-
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.Cassandra.system_update_column_family_args._Fields
-
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.Cassandra.system_update_column_family_result._Fields
-
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.Cassandra.system_update_keyspace_args._Fields
-
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.Cassandra.system_update_keyspace_result._Fields
-
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.Cassandra.trace_next_query_args._Fields
-
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.Cassandra.trace_next_query_result._Fields
-
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.Cassandra.truncate_args._Fields
-
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.Cassandra.truncate_result._Fields
-
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.CfDef._Fields
-
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.CfSplit._Fields
-
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.Column._Fields
-
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.ColumnDef._Fields
-
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.ColumnOrSuperColumn._Fields
-
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.ColumnParent._Fields
-
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.ColumnPath._Fields
-
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.ColumnSlice._Fields
-
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.Compression
-
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.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.thrift.CounterColumn._Fields
-
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.CounterSuperColumn._Fields
-
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.CqlMetadata._Fields
-
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.CqlPreparedResult._Fields
-
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.CqlResult._Fields
-
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.CqlResultType
-
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.CqlRow._Fields
-
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.Deletion._Fields
-
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.EndpointDetails._Fields
-
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.IndexClause._Fields
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
-
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.IndexOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.IndexType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
-
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.KeyCount._Fields
-
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.KeyRange._Fields
-
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.KeySlice._Fields
-
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.KsDef._Fields
-
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.MultiSliceRequest._Fields
-
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.Mutation._Fields
-
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.NotFoundException._Fields
-
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.SchemaDisagreementException._Fields
-
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.SlicePredicate._Fields
-
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.SliceRange._Fields
-
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.SuperColumn._Fields
-
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.TimedOutException._Fields
-
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.TokenRange._Fields
-
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.TriggerDef._Fields
-
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.UnavailableException._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.tracing.TraceState.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.DataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Target
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.AsymmetricOrdering.Op
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- values() - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- values() - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesAsComposites(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
-
- valueSet() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- valuesOf(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
-
- valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Sets
-
- VarcharAsBlobFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- variable_names - Variable in class org.apache.cassandra.thrift.CqlPreparedResult
-
- variable_types - Variable in class org.apache.cassandra.thrift.CqlPreparedResult
-
- 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
-
- 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
-
- Verifier - Class in org.apache.cassandra.db.compaction
-
- Verifier(ColumnFamilyStore, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
-
- Verifier(ColumnFamilyStore, SSTableReader, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
-
- verify(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- verify(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier
-
- verify() - Method in class org.apache.cassandra.service.StartupChecks
-
Run the configured tests and return a report detailing the results.
- verify(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- verify(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Verify (checksums of) the given keyspace.
- verify(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- verify(PrintStream, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Verify - Class in org.apache.cassandra.tools.nodetool
-
- Verify() - Constructor for class org.apache.cassandra.tools.nodetool.Verify
-
- verifyBatchSize(Iterable<ColumnFamily>) - Static method in class org.apache.cassandra.cql3.statements.BatchStatement
-
Checks batch size to ensure threshold is met.
- verifyFullPermissions(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Checks whether Cassandra has RWX permissions to the specified directory.
- verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- version - Variable in class org.apache.cassandra.gms.VersionedValue
-
- version - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
version has the following format: [a-z]+
- Version - Class in org.apache.cassandra.io.sstable.format
-
A set of feature flags associated with a SSTable format
versions are denoted as [major][minor].
- Version(SSTableFormat, String) - Constructor for class org.apache.cassandra.io.sstable.format.Version
-
- version - Variable in class org.apache.cassandra.io.sstable.format.Version
-
- version - 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.thrift.Cassandra.set_cql_version_args
-
- VERSION - Static variable in class org.apache.cassandra.thrift.cassandraConstants
-
- Version - Class in org.apache.cassandra.tools.nodetool
-
- Version() - Constructor for class org.apache.cassandra.tools.nodetool.Version
-
- version - Variable in class org.apache.cassandra.transport.Frame.Header
-
- version - Variable in class org.apache.cassandra.transport.SimpleClient
-
- VERSION_1 - Static variable in class org.apache.cassandra.transport.Server
-
- VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_2 - Static variable in class org.apache.cassandra.transport.Server
-
- VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
Streaming protocol version
- VERSION_21 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_21 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_22 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_22 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_22 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
- VERSION_3 - Static variable in class org.apache.cassandra.transport.Server
-
- VERSION_4 - Static variable in class org.apache.cassandra.transport.Server
-
- VersionedValue - Class in org.apache.cassandra.gms
-
This abstraction represents the state associated with a particular node which an
application wants to make available to the rest of the nodes in the cluster.
- VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
-
- VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- VersionGenerator - Class in org.apache.cassandra.gms
-
A unique version number generator for any state that is generated by the
local node.
- VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
-
- View - Class in org.apache.cassandra.db.lifecycle
-
An immutable structure holding the current memtable, the memtables pending
flush, the sstables for a column family, and the sstables that are active
in compaction (a subset of the sstables).
- viewFilter(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- viewFilter(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- viewFilter(Collection<AbstractBounds<RowPosition>>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- VINT - Static variable in class org.apache.cassandra.db.TypeSizes
-
- VIntEncodedTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- visible(SSTableReader, Predicate<SSTableReader>, Collection<SSTableReader>...) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
-
- Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
-