- CACHE_FLUSH_INTERVAL_IN_BYTES - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- 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.
- CacheKey - Interface in org.apache.cassandra.cache
-
- cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- CacheMetrics - Class in org.apache.cassandra.metrics
-
Metrics for ICache
.
- CacheMetrics(String, ICache) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
-
Create metrics for given cache.
- CacheService - Class in org.apache.cassandra.service
-
- CacheService.CacheType - Enum in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
-
- CacheService.RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- CacheServiceMBean - Interface in org.apache.cassandra.service
-
- cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- caching(CFMetaData.Caching) - Method in class org.apache.cassandra.config.CFMetaData
-
- caching - Variable in class org.apache.cassandra.thrift.CfDef
-
- calculateHintTTL(RowMutation) - Static method in class org.apache.cassandra.db.HintedHandOffManager
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the natural endpoints for the given token
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
calculate endpoints in one pass through the tokens by tracking our progress in each DC, rack etc.
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
-
Calculate pending ranges according to bootsrapping and leaving nodes.
- calculateRelocations(Multimap<String, String>) - Method in class org.apache.cassandra.tools.Shuffle
-
Given a Multimap of endpoint to tokens, return a new randomized mapping.
- calculateStreamAndFetchRanges(Collection<Range<Token>>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.StorageService
-
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
- callback - Variable in class org.apache.cassandra.net.CallbackInfo
-
- callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- callbackDeserializers - Static variable in class org.apache.cassandra.net.MessagingService
-
A Map of what kind of serializer to wire up to a REQUEST_RESPONSE callback, based on outbound Verb.
- CallbackInfo - Class in org.apache.cassandra.net
-
Encapsulates the callback information.
- CallbackInfo(InetAddress, IAsyncCallback, IVersionedSerializer<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
Create CallbackInfo without sent message
- canHaveOnlyOneValue() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- capacity() - Method in interface org.apache.cassandra.cache.ICache
-
- capacity() - Method in class org.apache.cassandra.cache.SerializingCache
-
- capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Cache capacity in bytes
- capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Returns the current capacity in bits (1 greater than the index of the last bit)
- cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- cas(String, String, ByteBuffer, CASConditions, ColumnFamily, ConsistencyLevel, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Apply @param updates if and only if the current values in the row for @param key
match the 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(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(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- cas_contention_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- CASConditions - Interface in org.apache.cassandra.service
-
Abstract the conditions to be fulfilled by 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.add_args
-
- Cassandra.add_args(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.add_args
-
- Cassandra.add_args(Cassandra.add_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.add_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.add_result
-
- Cassandra.add_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.add_result
-
- Cassandra.add_result(Cassandra.add_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.add_result
-
Performs a deep copy on other.
- 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(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient
-
- Cassandra.AsyncClient.add_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.add_call(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.add_call
-
- Cassandra.AsyncClient.atomic_batch_mutate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.atomic_batch_mutate_call(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.atomic_batch_mutate_call
-
- Cassandra.AsyncClient.batch_mutate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.batch_mutate_call(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.batch_mutate_call
-
- Cassandra.AsyncClient.cas_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.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
-
- Cassandra.AsyncClient.describe_cluster_name_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_cluster_name_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_cluster_name_call
-
- Cassandra.AsyncClient.describe_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_keyspace_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspace_call
-
- Cassandra.AsyncClient.describe_keyspaces_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_keyspaces_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspaces_call
-
- Cassandra.AsyncClient.describe_local_ring_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_local_ring_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_local_ring_call
-
- Cassandra.AsyncClient.describe_partitioner_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_partitioner_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_partitioner_call
-
- Cassandra.AsyncClient.describe_ring_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_ring_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_ring_call
-
- Cassandra.AsyncClient.describe_schema_versions_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_schema_versions_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_schema_versions_call
-
- Cassandra.AsyncClient.describe_snitch_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_snitch_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_snitch_call
-
- Cassandra.AsyncClient.describe_splits_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_splits_call(String, String, String, int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_call
-
- Cassandra.AsyncClient.describe_splits_ex_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_splits_ex_call(String, String, String, int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_ex_call
-
- Cassandra.AsyncClient.describe_token_map_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_token_map_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_token_map_call
-
- Cassandra.AsyncClient.describe_version_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.describe_version_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_version_call
-
- Cassandra.AsyncClient.execute_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_cql3_query_call(ByteBuffer, Compression, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_cql3_query_call
-
- Cassandra.AsyncClient.execute_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_cql_query_call(ByteBuffer, Compression, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_cql_query_call
-
- Cassandra.AsyncClient.execute_prepared_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_prepared_cql3_query_call(int, List<ByteBuffer>, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_prepared_cql3_query_call
-
- Cassandra.AsyncClient.execute_prepared_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.execute_prepared_cql_query_call(int, List<ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.execute_prepared_cql_query_call
-
- Cassandra.AsyncClient.Factory - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.Factory
-
- Cassandra.AsyncClient.get_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_call(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
-
- Cassandra.AsyncClient.get_count_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_count_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
-
- Cassandra.AsyncClient.get_indexed_slices_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.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
-
- Cassandra.AsyncClient.get_paged_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.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
-
- Cassandra.AsyncClient.get_range_slices_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.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
-
- Cassandra.AsyncClient.get_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.get_slice_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
-
- Cassandra.AsyncClient.insert_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.insert_call(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
-
- Cassandra.AsyncClient.login_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.login_call(AuthenticationRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.login_call
-
- Cassandra.AsyncClient.multiget_count_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.multiget_count_call(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_count_call
-
- Cassandra.AsyncClient.multiget_slice_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.multiget_slice_call(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_slice_call
-
- Cassandra.AsyncClient.prepare_cql3_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.prepare_cql3_query_call(ByteBuffer, Compression, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.prepare_cql3_query_call
-
- Cassandra.AsyncClient.prepare_cql_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.prepare_cql_query_call(ByteBuffer, Compression, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.prepare_cql_query_call
-
- Cassandra.AsyncClient.remove_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.remove_call(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
-
- Cassandra.AsyncClient.remove_counter_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.remove_counter_call(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_counter_call
-
- Cassandra.AsyncClient.set_cql_version_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.set_cql_version_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_cql_version_call
-
- Cassandra.AsyncClient.set_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.set_keyspace_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
-
- Cassandra.AsyncClient.system_add_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_add_column_family_call(CfDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
-
- Cassandra.AsyncClient.system_add_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_add_keyspace_call(KsDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
-
- Cassandra.AsyncClient.system_drop_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_drop_column_family_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
-
- Cassandra.AsyncClient.system_drop_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_drop_keyspace_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
-
- Cassandra.AsyncClient.system_update_column_family_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_update_column_family_call(CfDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
-
- Cassandra.AsyncClient.system_update_keyspace_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.system_update_keyspace_call(KsDef, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
-
- Cassandra.AsyncClient.trace_next_query_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.trace_next_query_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.trace_next_query_call
-
- Cassandra.AsyncClient.truncate_call - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncClient.truncate_call(String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.truncate_call
-
- Cassandra.AsyncIface - Interface in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor(I) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor
-
- Cassandra.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor
-
- Cassandra.AsyncProcessor.add<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.add() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.add
-
- Cassandra.AsyncProcessor.atomic_batch_mutate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.atomic_batch_mutate() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.atomic_batch_mutate
-
- Cassandra.AsyncProcessor.batch_mutate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.batch_mutate() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.batch_mutate
-
- Cassandra.AsyncProcessor.cas<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.cas() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.cas
-
- Cassandra.AsyncProcessor.describe_cluster_name<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_cluster_name() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_cluster_name
-
- Cassandra.AsyncProcessor.describe_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspace
-
- Cassandra.AsyncProcessor.describe_keyspaces<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_keyspaces() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_keyspaces
-
- Cassandra.AsyncProcessor.describe_local_ring<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_local_ring() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_local_ring
-
- Cassandra.AsyncProcessor.describe_partitioner<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_partitioner() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_partitioner
-
- Cassandra.AsyncProcessor.describe_ring<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_ring() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_ring
-
- Cassandra.AsyncProcessor.describe_schema_versions<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_schema_versions() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_schema_versions
-
- Cassandra.AsyncProcessor.describe_snitch<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_snitch() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_snitch
-
- Cassandra.AsyncProcessor.describe_splits<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_splits() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits
-
- Cassandra.AsyncProcessor.describe_splits_ex<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_splits_ex() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_splits_ex
-
- Cassandra.AsyncProcessor.describe_token_map<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_token_map() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_token_map
-
- Cassandra.AsyncProcessor.describe_version<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.describe_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.describe_version
-
- Cassandra.AsyncProcessor.execute_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql3_query
-
- Cassandra.AsyncProcessor.execute_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_cql_query
-
- Cassandra.AsyncProcessor.execute_prepared_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_prepared_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql3_query
-
- Cassandra.AsyncProcessor.execute_prepared_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.execute_prepared_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.execute_prepared_cql_query
-
- Cassandra.AsyncProcessor.get<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get
-
- Cassandra.AsyncProcessor.get_count<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_count
-
- Cassandra.AsyncProcessor.get_indexed_slices<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_indexed_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_indexed_slices
-
- Cassandra.AsyncProcessor.get_paged_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_paged_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_paged_slice
-
- Cassandra.AsyncProcessor.get_range_slices<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_range_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_range_slices
-
- Cassandra.AsyncProcessor.get_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.get_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.get_slice
-
- Cassandra.AsyncProcessor.insert<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.insert() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.insert
-
- Cassandra.AsyncProcessor.login<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.login() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.login
-
- Cassandra.AsyncProcessor.multiget_count<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.multiget_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_count
-
- Cassandra.AsyncProcessor.multiget_slice<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.multiget_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.multiget_slice
-
- Cassandra.AsyncProcessor.prepare_cql3_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.prepare_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql3_query
-
- Cassandra.AsyncProcessor.prepare_cql_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.prepare_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.prepare_cql_query
-
- Cassandra.AsyncProcessor.remove<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.remove() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove
-
- Cassandra.AsyncProcessor.remove_counter<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.remove_counter() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.remove_counter
-
- Cassandra.AsyncProcessor.set_cql_version<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.set_cql_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_cql_version
-
- Cassandra.AsyncProcessor.set_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.set_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.set_keyspace
-
- Cassandra.AsyncProcessor.system_add_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_add_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_column_family
-
- Cassandra.AsyncProcessor.system_add_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_add_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_add_keyspace
-
- Cassandra.AsyncProcessor.system_drop_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_drop_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_column_family
-
- Cassandra.AsyncProcessor.system_drop_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_drop_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_drop_keyspace
-
- Cassandra.AsyncProcessor.system_update_column_family<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_update_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_column_family
-
- Cassandra.AsyncProcessor.system_update_keyspace<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.system_update_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.system_update_keyspace
-
- Cassandra.AsyncProcessor.trace_next_query<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.trace_next_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.trace_next_query
-
- Cassandra.AsyncProcessor.truncate<I extends Cassandra.AsyncIface> - Class in org.apache.cassandra.thrift
-
- Cassandra.AsyncProcessor.truncate() - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncProcessor.truncate
-
- Cassandra.atomic_batch_mutate_args - Class in org.apache.cassandra.thrift
-
- Cassandra.atomic_batch_mutate_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- Cassandra.atomic_batch_mutate_args(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
- Cassandra.atomic_batch_mutate_args(Cassandra.atomic_batch_mutate_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- Cassandra.atomic_batch_mutate_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
- Cassandra.atomic_batch_mutate_result(Cassandra.atomic_batch_mutate_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.atomic_batch_mutate_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- Cassandra.batch_mutate_args(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
- Cassandra.batch_mutate_args(Cassandra.batch_mutate_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- Cassandra.batch_mutate_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
- Cassandra.batch_mutate_result(Cassandra.batch_mutate_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
- Cassandra.cas_args(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
- Cassandra.cas_args(Cassandra.cas_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
- Cassandra.cas_result(CASResult, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
- Cassandra.cas_result(Cassandra.cas_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.cas_result
-
Performs a deep copy on other.
- 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(TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
-
- Cassandra.Client(TProtocol, TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
-
- Cassandra.Client.Factory - Class in org.apache.cassandra.thrift
-
- Cassandra.Client.Factory() - Constructor for class org.apache.cassandra.thrift.Cassandra.Client.Factory
-
- Cassandra.describe_cluster_name_args - Class in org.apache.cassandra.thrift
-
- Cassandra.describe_cluster_name_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
- Cassandra.describe_cluster_name_args(Cassandra.describe_cluster_name_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- Cassandra.describe_cluster_name_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
- Cassandra.describe_cluster_name_result(Cassandra.describe_cluster_name_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- Cassandra.describe_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
- Cassandra.describe_keyspace_args(Cassandra.describe_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- Cassandra.describe_keyspace_result(KsDef, NotFoundException, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- Cassandra.describe_keyspace_result(Cassandra.describe_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
- Cassandra.describe_keyspaces_args(Cassandra.describe_keyspaces_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- Cassandra.describe_keyspaces_result(List<KsDef>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
- Cassandra.describe_keyspaces_result(Cassandra.describe_keyspaces_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- Cassandra.describe_local_ring_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
- Cassandra.describe_local_ring_args(Cassandra.describe_local_ring_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- Cassandra.describe_local_ring_result(List<TokenRange>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
- Cassandra.describe_local_ring_result(Cassandra.describe_local_ring_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_local_ring_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
- Cassandra.describe_partitioner_args(Cassandra.describe_partitioner_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- Cassandra.describe_partitioner_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
- Cassandra.describe_partitioner_result(Cassandra.describe_partitioner_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- Cassandra.describe_ring_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
- Cassandra.describe_ring_args(Cassandra.describe_ring_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- Cassandra.describe_ring_result(List<TokenRange>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
- Cassandra.describe_ring_result(Cassandra.describe_ring_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
- Cassandra.describe_schema_versions_args(Cassandra.describe_schema_versions_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- Cassandra.describe_schema_versions_result(Map<String, List<String>>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
- Cassandra.describe_schema_versions_result(Cassandra.describe_schema_versions_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
- Cassandra.describe_snitch_args(Cassandra.describe_snitch_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- Cassandra.describe_snitch_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
- Cassandra.describe_snitch_result(Cassandra.describe_snitch_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- Cassandra.describe_splits_args(String, String, String, int) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
- Cassandra.describe_splits_args(Cassandra.describe_splits_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- Cassandra.describe_splits_ex_args(String, String, String, int) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
- Cassandra.describe_splits_ex_args(Cassandra.describe_splits_ex_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- Cassandra.describe_splits_ex_result(List<CfSplit>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
- Cassandra.describe_splits_ex_result(Cassandra.describe_splits_ex_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_ex_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- Cassandra.describe_splits_result(List<String>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
- Cassandra.describe_splits_result(Cassandra.describe_splits_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
- Cassandra.describe_token_map_args(Cassandra.describe_token_map_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_token_map_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- Cassandra.describe_token_map_result(Map<String, String>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
- Cassandra.describe_token_map_result(Cassandra.describe_token_map_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_token_map_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
- Cassandra.describe_version_args(Cassandra.describe_version_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- Cassandra.describe_version_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
- Cassandra.describe_version_result(Cassandra.describe_version_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- Cassandra.execute_cql3_query_args(ByteBuffer, Compression, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- Cassandra.execute_cql3_query_args(Cassandra.execute_cql3_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- Cassandra.execute_cql3_query_result(CqlResult, InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
- Cassandra.execute_cql3_query_result(Cassandra.execute_cql3_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- Cassandra.execute_cql_query_args(ByteBuffer, Compression) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
- Cassandra.execute_cql_query_args(Cassandra.execute_cql_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- Cassandra.execute_cql_query_result(CqlResult, InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
- Cassandra.execute_cql_query_result(Cassandra.execute_cql_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_cql_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- Cassandra.execute_prepared_cql3_query_args(int, List<ByteBuffer>, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- Cassandra.execute_prepared_cql3_query_args(Cassandra.execute_prepared_cql3_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- Cassandra.execute_prepared_cql3_query_result(CqlResult, InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
- Cassandra.execute_prepared_cql3_query_result(Cassandra.execute_prepared_cql3_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- Cassandra.execute_prepared_cql_query_args(int, List<ByteBuffer>) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
- Cassandra.execute_prepared_cql_query_args(Cassandra.execute_prepared_cql_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- Cassandra.execute_prepared_cql_query_result(CqlResult, InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
- Cassandra.execute_prepared_cql_query_result(Cassandra.execute_prepared_cql_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
- Cassandra.get_args(ByteBuffer, ColumnPath, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
- Cassandra.get_args(Cassandra.get_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- Cassandra.get_count_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
- Cassandra.get_count_args(Cassandra.get_count_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- Cassandra.get_count_result(int, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
- Cassandra.get_count_result(Cassandra.get_count_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- Cassandra.get_indexed_slices_args(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- Cassandra.get_indexed_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
-
- Cassandra.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.
- 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_paged_slice_args - Class in org.apache.cassandra.thrift
-
- Cassandra.get_paged_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- Cassandra.get_paged_slice_args(String, KeyRange, ByteBuffer, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- Cassandra.get_paged_slice_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_paged_slice_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- Cassandra.get_range_slices_args(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- Cassandra.get_range_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
- Cassandra.get_result(ColumnOrSuperColumn, InvalidRequestException, NotFoundException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
- Cassandra.get_result(Cassandra.get_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- Cassandra.get_slice_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
- Cassandra.get_slice_args(Cassandra.get_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- Cassandra.get_slice_result(List<ColumnOrSuperColumn>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
- Cassandra.get_slice_result(Cassandra.get_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
- Cassandra.insert_args(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
- Cassandra.insert_args(Cassandra.insert_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
- Cassandra.insert_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
- Cassandra.insert_result(Cassandra.insert_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
-
- Cassandra.login_args(AuthenticationRequest) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
-
- Cassandra.login_args(Cassandra.login_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
-
- Cassandra.login_result(AuthenticationException, AuthorizationException) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
-
- Cassandra.login_result(Cassandra.login_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- Cassandra.multiget_count_args(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- Cassandra.multiget_count_args(Cassandra.multiget_count_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- Cassandra.multiget_count_result(Map<ByteBuffer, Integer>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
- Cassandra.multiget_count_result(Cassandra.multiget_count_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- Cassandra.multiget_slice_args(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- Cassandra.multiget_slice_args(Cassandra.multiget_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- Cassandra.multiget_slice_result(Map<ByteBuffer, List<ColumnOrSuperColumn>>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
- Cassandra.multiget_slice_result(Cassandra.multiget_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- Cassandra.prepare_cql3_query_args(ByteBuffer, Compression) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
- Cassandra.prepare_cql3_query_args(Cassandra.prepare_cql3_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- Cassandra.prepare_cql3_query_result(CqlPreparedResult, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
- Cassandra.prepare_cql3_query_result(Cassandra.prepare_cql3_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql3_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- Cassandra.prepare_cql_query_args(ByteBuffer, Compression) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
- Cassandra.prepare_cql_query_args(Cassandra.prepare_cql_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- Cassandra.prepare_cql_query_result(CqlPreparedResult, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
- Cassandra.prepare_cql_query_result(Cassandra.prepare_cql_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.prepare_cql_query_result
-
Performs a deep copy on other.
- 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(I) - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor
-
- Cassandra.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor
-
- Cassandra.Processor.add<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.add() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.add
-
- Cassandra.Processor.atomic_batch_mutate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.atomic_batch_mutate() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.atomic_batch_mutate
-
- Cassandra.Processor.batch_mutate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.batch_mutate() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.batch_mutate
-
- Cassandra.Processor.cas<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.cas() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.cas
-
- Cassandra.Processor.describe_cluster_name<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_cluster_name() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_cluster_name
-
- Cassandra.Processor.describe_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspace
-
- Cassandra.Processor.describe_keyspaces<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_keyspaces() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_keyspaces
-
- Cassandra.Processor.describe_local_ring<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_local_ring() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_local_ring
-
- Cassandra.Processor.describe_partitioner<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_partitioner() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_partitioner
-
- Cassandra.Processor.describe_ring<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_ring() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_ring
-
- Cassandra.Processor.describe_schema_versions<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_schema_versions() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_schema_versions
-
- Cassandra.Processor.describe_snitch<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_snitch() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_snitch
-
- Cassandra.Processor.describe_splits<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_splits() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits
-
- Cassandra.Processor.describe_splits_ex<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_splits_ex() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_splits_ex
-
- Cassandra.Processor.describe_token_map<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_token_map() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_token_map
-
- Cassandra.Processor.describe_version<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.describe_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.describe_version
-
- Cassandra.Processor.execute_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql3_query
-
- Cassandra.Processor.execute_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.execute_cql_query
-
- Cassandra.Processor.execute_prepared_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_prepared_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql3_query
-
- Cassandra.Processor.execute_prepared_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.execute_prepared_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.execute_prepared_cql_query
-
- Cassandra.Processor.get<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get
-
- Cassandra.Processor.get_count<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_count
-
- Cassandra.Processor.get_indexed_slices<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_indexed_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_indexed_slices
-
- Cassandra.Processor.get_paged_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_paged_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_paged_slice
-
- Cassandra.Processor.get_range_slices<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_range_slices() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_range_slices
-
- Cassandra.Processor.get_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.get_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.get_slice
-
- Cassandra.Processor.insert<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.insert() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.insert
-
- Cassandra.Processor.login<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.login() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.login
-
- Cassandra.Processor.multiget_count<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.multiget_count() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.multiget_count
-
- Cassandra.Processor.multiget_slice<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.multiget_slice() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.multiget_slice
-
- Cassandra.Processor.prepare_cql3_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.prepare_cql3_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql3_query
-
- Cassandra.Processor.prepare_cql_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.prepare_cql_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.prepare_cql_query
-
- Cassandra.Processor.remove<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.remove() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.remove
-
- Cassandra.Processor.remove_counter<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.remove_counter() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.remove_counter
-
- Cassandra.Processor.set_cql_version<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.set_cql_version() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.set_cql_version
-
- Cassandra.Processor.set_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.set_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.set_keyspace
-
- Cassandra.Processor.system_add_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_add_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_add_column_family
-
- Cassandra.Processor.system_add_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_add_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_add_keyspace
-
- Cassandra.Processor.system_drop_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_drop_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_column_family
-
- Cassandra.Processor.system_drop_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_drop_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_drop_keyspace
-
- Cassandra.Processor.system_update_column_family<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_update_column_family() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_update_column_family
-
- Cassandra.Processor.system_update_keyspace<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.system_update_keyspace() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.system_update_keyspace
-
- Cassandra.Processor.trace_next_query<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.trace_next_query() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.trace_next_query
-
- Cassandra.Processor.truncate<I extends Cassandra.Iface> - Class in org.apache.cassandra.thrift
-
- Cassandra.Processor.truncate() - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor.truncate
-
- Cassandra.remove_args - Class in org.apache.cassandra.thrift
-
- Cassandra.remove_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
- Cassandra.remove_args(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
- Cassandra.remove_args(Cassandra.remove_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- Cassandra.remove_counter_args(ByteBuffer, ColumnPath, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- Cassandra.remove_counter_args(Cassandra.remove_counter_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- Cassandra.remove_counter_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
- Cassandra.remove_counter_result(Cassandra.remove_counter_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_counter_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
- Cassandra.remove_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
- Cassandra.remove_result(Cassandra.remove_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- Cassandra.set_cql_version_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- Cassandra.set_cql_version_result(InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_cql_version_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- Cassandra.set_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
- Cassandra.set_keyspace_args(Cassandra.set_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- Cassandra.set_keyspace_result(InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
- Cassandra.set_keyspace_result(Cassandra.set_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- Cassandra.system_add_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- Cassandra.system_add_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- Cassandra.system_add_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- Cassandra.system_add_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- Cassandra.system_drop_column_family_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- Cassandra.system_drop_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- Cassandra.system_drop_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- Cassandra.system_drop_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- Cassandra.system_update_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- Cassandra.system_update_column_family_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- Cassandra.system_update_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- Cassandra.system_update_keyspace_result(String, InvalidRequestException, SchemaDisagreementException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
-
- Cassandra.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.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
- Cassandra.trace_next_query_args(Cassandra.trace_next_query_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.trace_next_query_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- Cassandra.trace_next_query_result(ByteBuffer) - Constructor for class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
- Cassandra.trace_next_query_result(Cassandra.trace_next_query_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.trace_next_query_result
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- Cassandra.truncate_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
-
- Cassandra.truncate_args(Cassandra.truncate_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
-
Performs a deep copy on other.
- 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() - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- Cassandra.truncate_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
-
- Cassandra.truncate_result(Cassandra.truncate_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
-
Performs a deep copy on other.
- 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
-
- CassandraAuthorizer - Class in org.apache.cassandra.auth
-
CassandraAuthorizer is an IAuthorizer implementation that keeps
permissions internally in C* - in system_auth.permissions CQL3 table.
- CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
-
- 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.Server - Interface in org.apache.cassandra.service
-
- CassandraException - Exception in org.apache.cassandra.exceptions
-
- CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraServer - Class in org.apache.cassandra.thrift
-
- CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
-
- cassandraServer - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- CassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
A row from a standard CF will be returned as nested tuples: (key, ((name1, val1), (name2, val2))).
- CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- cassandraToObj(AbstractType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- CBCodec<T> - Interface in org.apache.cassandra.transport
-
- CBUtil - Class in org.apache.cassandra.transport
-
ChannelBuffer utility methods.
- cellName - Variable in class org.apache.cassandra.service.pager.PagingState
-
- cf - Variable in class org.apache.cassandra.db.Row
-
- 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 - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
-
- 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.AbstractCassandraStorage
-
convert string back to CfDef
- CFDefinition - Class in org.apache.cassandra.cql3
-
Holds metadata on a CF preprocessed for use by CQL queries.
- CFDefinition(CFMetaData) - Constructor for class org.apache.cassandra.cql3.CFDefinition
-
- CFDefinition.Name - Class in org.apache.cassandra.cql3
-
- CFDefinition.Name.Kind - Enum in org.apache.cassandra.cql3
-
- cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert CfDef to string
- cfId - Variable in class org.apache.cassandra.cache.RowCacheKey
-
- cfId - Variable in class org.apache.cassandra.config.CFMetaData
-
- cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamReader
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamSummary
-
- cfId - Variable in class org.apache.cassandra.streaming.StreamTask
-
- cfIdSerializedSize(UUID, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- cfm - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- cfm - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- CFMetaData - Class in org.apache.cassandra.config
-
- CFMetaData(String, String, ColumnFamilyType, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.config.CFMetaData
-
- CFMetaData(String, String, ColumnFamilyType, AbstractType<?>) - Constructor for class org.apache.cassandra.config.CFMetaData
-
- cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
-
- CFMetaData.Caching - Enum in org.apache.cassandra.config
-
- CFMetaData.SpeculativeRetry - Class in org.apache.cassandra.config
-
- CFMetaData.SpeculativeRetry.RetryType - Enum in org.apache.cassandra.config
-
- cfName - Variable in class org.apache.cassandra.config.CFMetaData
-
- CFName - Class in org.apache.cassandra.cql3
-
- CFName() - Constructor for class org.apache.cassandra.cql3.CFName
-
- cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
-
- cfName - Variable in class org.apache.cassandra.db.filter.QueryFilter
-
- cfName - Variable in class org.apache.cassandra.db.ReadCommand
-
- cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- 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.cql
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql.CFPropDefs
-
- CFPropDefs - Class in org.apache.cassandra.cql3.statements
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.CFPropDefs
-
- cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- cfs - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- cfs - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- cfs - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
-
- cfs - Variable in class org.apache.cassandra.db.Memtable
-
- 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
-
- cfstore - Variable in class org.apache.cassandra.db.DataTracker
-
- cfType - Variable in class org.apache.cassandra.config.CFMetaData
-
- chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
-
Construct a chain of resource parents starting with the resource and ending with the root.
- change - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- change - Variable in class org.apache.cassandra.transport.Event.TopologyChange
-
- change - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- changeType() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- channel() - Method in class org.apache.cassandra.transport.Connection
-
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
-
- CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform any access verification necessary for the statement.
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- checkForEndpointCollision() - Method in class org.apache.cassandra.service.StorageService
-
- checkHealth() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
One of three things will happen if you try to read the system keyspace:
1.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- checkSeedContact(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- ChecksummedOutputStream - Class in org.apache.cassandra.io.util
-
- ChecksummedOutputStream(OutputStream, Checksum) - Constructor for class org.apache.cassandra.io.util.ChecksummedOutputStream
-
- checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- checksumWriter(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- chunkFor(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Get a chunk of compressed data (offset, length) corresponding to given position
- chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- chunkOffsetBy(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Get a chunk offset by it's index.
- chunks - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- CIPHER_SUITES - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
-
- class_name - Variable in class org.apache.cassandra.config.SeedProviderDef
-
- classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- classOption - Variable in class org.apache.cassandra.config.TriggerDefinition
-
- clean(MappedByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cleanup() - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- cleanup() - Method in class org.apache.cassandra.io.util.SegmentedFile
-
Do whatever action is needed to reclaim ressources used by this SegmentedFile.
- cleanup() - Method in class org.apache.cassandra.streaming.StreamLockfile
-
- cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- clear() - Method in interface org.apache.cassandra.cache.ICache
-
- clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- clear() - Method in class org.apache.cassandra.cache.SerializingCache
-
- clear() - Method in class org.apache.cassandra.config.Schema
-
Clear all KS/CF metadata and reset version.
- clear() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clear this column family, removing all columns and deletion info.
- clear() - Method in class org.apache.cassandra.db.EmptyColumns
-
- clear(String) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear(String, Schema) - Static method in class org.apache.cassandra.db.Keyspace
-
- clear() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- clear() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- clear() - Static method in class org.apache.cassandra.sink.SinkManager
-
- 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_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.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.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.tools.Shuffle
-
Clear pending token relocations on all nodes.
- clear() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- clear() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- clear() - Method in class org.apache.cassandra.utils.BloomFilter
-
- clear() - Method in class org.apache.cassandra.utils.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
-
- 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
-
- clearKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace definition from system
- clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
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.
- 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
- cLevel - Variable in class org.apache.cassandra.cql.AbstractModification
-
- CLibrary - Class in org.apache.cassandra.utils
-
- CliClient - Class in org.apache.cassandra.cli
-
- CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
-
- CliClient.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
-
- CliClient.Function - Enum in org.apache.cassandra.cli
-
Available value conversion functions
Used by convertValueByFunction(Tree functionCall) method
- CliCommandHelp - Class in org.apache.cassandra.cli
-
- CliCommandHelp() - Constructor for class org.apache.cassandra.cli.CliCommandHelp
-
- CliCompiler - Class in org.apache.cassandra.cli
-
- CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
-
- CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
-
- CliCompiler.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
-
- CliCompleter - Class in org.apache.cassandra.cli
-
- CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
-
- client - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- Client - Class in org.apache.cassandra.transport
-
- Client(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
-
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- 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 - Variable in class org.apache.cassandra.cql.hooks.ExecutionContext
-
- clientState - Variable in class org.apache.cassandra.cql.hooks.PreparationContext
-
- ClientState - Class in org.apache.cassandra.service
-
State related to a client connection.
- ClientState(SocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
-
- CliMain - Class in org.apache.cassandra.cli
-
Cassandra Command Line Interface (CLI) Main
- CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
-
- CliOptions - Class in org.apache.cassandra.cli
-
Used to process, and act upon the arguments passed to the CLI.
- CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
-
- CliSessionState - Class in org.apache.cassandra.cli
-
Used to hold the state for the CLI.
- CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
-
- CliUserHelp - Class in org.apache.cassandra.cli
-
- CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
-
- CliUtils - Class in org.apache.cassandra.cli
-
- CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
-
- clone() - Method in class org.apache.cassandra.config.CFMetaData
-
- clone() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.Allocator
-
Allocate a slice of the given length.
- clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave operations have finished.
- cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all
current leave, move, and relocate operations have finished.
- cloneMe() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
-
Clones the column map.
- cloneMe() - Method in class org.apache.cassandra.db.EmptyColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- cloneMe() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- cloneMeShallow(ColumnFamily.Factory<T>, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
-
- cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with only tokenToEndpointMap.
- cloneShallow() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- cloneShallow() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- cloneWith(KSMetaData, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
-
- cloneWithHigherVersion(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- cloneWithNewName(ByteBuffer) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- close() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- close() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
clean up any open resources
- close() - Method in class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- close() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Close the segment file.
- close() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- close() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- close() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- close() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Close this RecordWriter
to future operations, but not before
flushing out the batched mutations.
- close(Reporter) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- close() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- close() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Clean up all opened resources.
- close() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Closes this stream and frees resources associated with this stream.
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Closes this stream.
- close(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- close() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- close() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- close() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- close() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Closes the socket.
- close() - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- close() - Method in class org.apache.cassandra.tools.NodeProbe
-
- close() - Method in class org.apache.cassandra.transport.SimpleClient
-
- close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- close() - Method in class org.apache.cassandra.utils.BloomFilter
-
- close(int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- close() - Method in class org.apache.cassandra.utils.MergeIterator
-
- close() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
May be overridden by implementations that require cleaning up after use
- close() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- close() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
-
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeAll() - Method in interface org.apache.cassandra.transport.Connection.Tracker
-
- closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- closeAndOpenReader() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeAndOpenReader(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeInternal() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cluster_name - Variable in class org.apache.cassandra.config.Config
-
- clusteringColumns() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- clusteringColumnsCount() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- clusteringKeyColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- clusteringKeyDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- cmdCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
-
- code() - Method in exception org.apache.cassandra.exceptions.CassandraException
-
- code() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception code.
- code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- code() - Method in exception org.apache.cassandra.transport.ProtocolException
-
- code() - Method in exception org.apache.cassandra.transport.ServerError
-
- codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet
-
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- codec - Static variable in enum org.apache.cassandra.transport.DataType
-
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthChallenge
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
-
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
-
- codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ErrorMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.EventMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.OptionsMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.PrepareMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.QueryMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ReadyMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.RegisterMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- codec - Static variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- COLD_READS_TO_OMIT_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- coldReadsToOmit - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- collateColumns(ColumnFamily, List<? extends Iterator<Column>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateColumns(ColumnFamily, List<? extends Iterator<Column>>, IDiskAtomFilter, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, IDiskAtomFilter, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- collateOnDiskAtom(ColumnFamily, Iterator<? extends OnDiskAtom>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
When there is only a single source of atoms, we can skip the collate step
- CollationController - Class in org.apache.cassandra.db
-
- CollationController(ColumnFamilyStore, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
-
- collectionEqual(Term.Raw, Term.Raw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
- CollectionSerializer<T> - Class in org.apache.cassandra.serializers
-
- CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
-
- CollectionType<T> - Class in org.apache.cassandra.db.marshal
-
The abstract validator that is the base for maps, sets and lists.
- CollectionType(CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
-
- CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Attributes
-
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.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
-
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
collects columns from reducedColumns into returnCF.
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- collectReducedColumns(ColumnFamily, Iterator<Column>, int, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- column - Variable in class org.apache.cassandra.cql3.ColumnCondition
-
- Column - Class in org.apache.cassandra.db
-
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
- Column(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.Column
-
- Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.Column
-
- column - 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.AbstractCassandraStorage
-
- 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_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_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- columnComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- ColumnCondition - Class in org.apache.cassandra.cql3
-
A CQL3 condition.
- ColumnCondition.Raw - Class in org.apache.cassandra.cql3
-
- ColumnCondition.WithVariables - Class in org.apache.cassandra.cql3
-
- columnCount - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- columnCount - Variable in class org.apache.cassandra.io.sstable.ColumnStats
-
how many columns are there in the row
- ColumnCounter - Class in org.apache.cassandra.db.filter
-
- ColumnCounter(long) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter
-
- columnCounter(AbstractType<?>, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- columnCounter(AbstractType<?>, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columnCounter(AbstractType<?>, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- columnCounter() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- columnCounter() - Method in interface org.apache.cassandra.service.pager.SinglePartitionPager
-
- ColumnCounter.GroupByPrefix - Class in org.apache.cassandra.db.filter
-
- ColumnCounter.GroupByPrefix(long, CompositeType, int) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
A column counter that count only 1 for all the columns sharing a
given prefix of the key.
- columnDef - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- 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(ByteBuffer, AbstractType<?>, Integer, ColumnDefinition.Type) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition(ByteBuffer, AbstractType<?>, IndexType, Map<String, String>, String, Integer, ColumnDefinition.Type) - Constructor for class org.apache.cassandra.config.ColumnDefinition
-
- ColumnDefinition.Type - Enum in org.apache.cassandra.config
-
- columnDefs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
-
The column definitions which this index is responsible for
- columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- columnFamily(String, String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource instance representing a column family.
- columnFamily - Variable in class org.apache.cassandra.cql.AbstractModification
-
- columnFamily - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- columnFamily - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- ColumnFamily - Class in org.apache.cassandra.db
-
A sorted map of columns.
- ColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.ColumnFamily
-
- columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
-
- columnFamily - Variable in class org.apache.cassandra.db.Truncation
-
- columnFamily - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
- columnFamily - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ColumnFamily.Factory<T extends ColumnFamily> - Class in org.apache.cassandra.db
-
- ColumnFamily.Factory() - Constructor for class org.apache.cassandra.db.ColumnFamily.Factory
-
- ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- ColumnFamilyMetrics - Class in org.apache.cassandra.metrics
-
- ColumnFamilyMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- columnFamilyName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- ColumnFamilyNotDefinedException - Exception in org.apache.cassandra.db
-
- ColumnFamilyNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.ColumnFamilyNotDefinedException
-
- ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
values) as Cassandra rows (and respective columns) in a given
ColumnFamily.
- ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
- ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
-
- ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilySerializer - Class in org.apache.cassandra.db
-
- ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
-
- ColumnFamilySplit - Class in org.apache.cassandra.hadoop
-
- ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
Deprecated.
- ColumnFamilySplit(String, String, long, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilyStore - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.AbstractScanIterator() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
-
- ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
-
The MBean interface for ColumnFamilyStore
- ColumnFamilyType - Enum in org.apache.cassandra.db
-
column family type enum
- columnFilter - Variable in class org.apache.cassandra.db.DataRange
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- ColumnGroupMap - Class in org.apache.cassandra.cql3.statements
-
- ColumnGroupMap.Builder - Class in org.apache.cassandra.cql3.statements
-
- ColumnGroupMap.Builder(CompositeType, boolean, long) - Constructor for class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- ColumnIdentifier - Class in org.apache.cassandra.cql3
-
Represents an identifer for a CQL column definition.
- ColumnIdentifier(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIdentifier(ByteBuffer, AbstractType) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
-
- ColumnIndex - Class in org.apache.cassandra.db
-
- ColumnIndex.Builder - Class in org.apache.cassandra.db
-
Help to create an index for a column family based on size of columns,
and write said columns to disk.
- ColumnIndex.Builder(ColumnFamily, ByteBuffer, DataOutput) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
-
- columnMetadata(Map<ByteBuffer, ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
-
- columnName - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnName - Variable in class org.apache.cassandra.cql3.Operation
-
- columnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- ColumnNameBuilder - Interface in org.apache.cassandra.cql3
-
Build a potentially composite column name.
- ColumnNameHelper - Class in org.apache.cassandra.io.sstable
-
- ColumnNameHelper() - Constructor for class org.apache.cassandra.io.sstable.ColumnNameHelper
-
- 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 - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- columns - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columns - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- 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() - Constructor for class org.apache.cassandra.db.ColumnSerializer
-
- ColumnSerializer.CorruptColumnException - Exception in org.apache.cassandra.db
-
- ColumnSerializer.CorruptColumnException(String) - Constructor for exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- ColumnSerializer.Flag - Enum in org.apache.cassandra.db
-
Flag affecting deserialization behavior.
- columnsIndex - Variable in class org.apache.cassandra.db.ColumnIndex
-
- columnsIndex() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- ColumnSlice - Class in org.apache.cassandra.db.filter
-
- ColumnSlice(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice
-
- ColumnSlice.NavigableMapIterator - Class in org.apache.cassandra.db.filter
-
- ColumnSlice.NavigableMapIterator(NavigableMap<ByteBuffer, Column>, ColumnSlice[]) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
-
- ColumnSlice.Serializer - Class in org.apache.cassandra.db.filter
-
- ColumnSlice.Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- ColumnSpecification - Class in org.apache.cassandra.cql3
-
- ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- columnStats() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- ColumnStats - Class in org.apache.cassandra.io.sstable
-
ColumnStats holds information about the columns for one row inside sstable
- ColumnStats(int, long, long, int, StreamingHistogram, List<ByteBuffer>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats
-
- ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
-
- columnToTuple(Column, AbstractCassandraStorage.CfInfo, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert a column to a tuple
- command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- commandCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- commandDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- commandPendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- commands - Variable in class org.apache.cassandra.cli.CliUserHelp
-
- commands - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- commands - Variable in class org.apache.cassandra.tools.NodeToolHelp
-
- commandType - Variable in class org.apache.cassandra.db.ReadCommand
-
- comment(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- comment - Variable in class org.apache.cassandra.thrift.CfDef
-
- Commit - Class in org.apache.cassandra.service.paxos
-
- Commit(ByteBuffer, UUID, ColumnFamily) - Constructor for class org.apache.cassandra.service.paxos.Commit
-
- commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
-
- Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
-
- Commit.CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- 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_directory - Variable in class org.apache.cassandra.config.Config
-
- commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
-
- commitlog_segment_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- CommitLogAllocator - Class in org.apache.cassandra.db.commitlog
-
Performs the pre-allocation of commit log segments in a background thread.
- CommitLogAllocator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
-
- CommitLogArchiver() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
-
- CommitLogDescriptor(int, long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogDescriptor(long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogMetrics - Class in org.apache.cassandra.metrics
-
Metrics for commit log
- CommitLogMetrics(ICommitLogExecutorService, CommitLogAllocator) - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
-
- CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- CommitLogSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- CommitVerbHandler - Class in org.apache.cassandra.service.paxos
-
- CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
-
- compact() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- COMPACTED_MARKER - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
-
- CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- COMPACTION_HISTORY_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- COMPACTION_LOG - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- COMPACTION_OPTIONS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- compaction_preheat_key_cache - Variable in class org.apache.cassandra.config.Config
-
- compaction_strategy - 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
-
- CompactionController - Class in org.apache.cassandra.db.compaction
-
Manage compaction options.
- CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
Constructor that subclasses may use when overriding shouldPurge to not need overlappingTree
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
-
- CompactionHistoryCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CompactionHistoryTabularData - Class in org.apache.cassandra.db.compaction
-
- CompactionHistoryTabularData() - Constructor for class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- CompactionInfo - Class in org.apache.cassandra.db.compaction
-
Implements serializable to allow structured info to be returned via JMX.
- CompactionInfo(CFMetaData, OperationType, long, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(CFMetaData, OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
-
- CompactionInfo.Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- CompactionInterruptedException - Exception in org.apache.cassandra.db.compaction
-
- CompactionInterruptedException(CompactionInfo) - Constructor for exception org.apache.cassandra.db.compaction.CompactionInterruptedException
-
- CompactionIterable - Class in org.apache.cassandra.db.compaction
-
- CompactionIterable(OperationType, List<ICompactionScanner>, CompactionController) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
-
- CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
-
- CompactionIterable.Reducer() - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- CompactionLogCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CompactionManager - Class in org.apache.cassandra.db.compaction
-
A singleton which manages a private executor of ongoing compactions.
- CompactionManager() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager
-
- CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
-
- CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
-
- CompactionMetrics - Class in org.apache.cassandra.metrics
-
Metrics for compaction.
- CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
-
- compactionStrategyClass - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyClass(Class<? extends AbstractCompactionStrategy>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyClass - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompactionTask - Class in org.apache.cassandra.db.compaction
-
- CompactionTask(ColumnFamilyStore, Iterable<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
-
- compactionType - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- compactionType - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- compactValue() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- compactValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
-
- compactValueDef(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.commitlog.ReplayPosition
-
- comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
-
- comparator - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- comparator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- comparator_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- comparators - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- compare(SSTableReader, SSTableReader) - Method in class org.apache.cassandra.io.sstable.SSTableReader.SizeComparator
-
- compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
- compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
- compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
determine which endpoint started up earlier
- compareIdTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- compareLongs(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.LongType
-
- compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Compare two ByteBuffer at specified offsets for length.
- compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
-
- compareTo(RowCacheKey) - Method in class org.apache.cassandra.cache.RowCacheKey
-
- compareTo(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
-
- compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- compareTo(RowPosition) - Method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(IPartitioner, ByteBuffer, RowPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
-
- compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
-
- compareTo(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- compareTo(Token<BigInteger>) - Method in class org.apache.cassandra.dht.BigIntegerToken
-
- compareTo(Token<byte[]>) - Method in class org.apache.cassandra.dht.BytesToken
-
- compareTo(Token<ByteBuffer>) - Method in class org.apache.cassandra.dht.LocalToken
-
- compareTo(Token<Long>) - Method in class org.apache.cassandra.dht.LongToken
-
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- compareTo(Token<String>) - Method in class org.apache.cassandra.dht.StringToken
-
- compareTo(Token<T>) - Method in class org.apache.cassandra.dht.Token
-
This determines the comparison for node destination purposes.
- compareTo(RowPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
-
- compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
-
- compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- compareTo(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_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(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(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(CounterId) - Method in class org.apache.cassandra.utils.CounterId
-
- compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
-
- compareTo(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- compile(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- complete(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- complete(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
- complete() - Method in class org.apache.cassandra.repair.Validator
-
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
- complete() - Method in class org.apache.cassandra.streaming.StreamSession
-
Check if session is completed on receiving StreamMessage.Type.COMPLETE
message.
- complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for file at sequenceNumber
.
- completed(R) - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- completedTaskCount - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Number of completed tasks
- completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Number of completed compactions since server [re]start
- completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of completed tasks.
- CompleteMessage - Class in org.apache.cassandra.streaming.messages
-
- CompleteMessage() - Constructor for class org.apache.cassandra.streaming.messages.CompleteMessage
-
- completeTree() - Method in class org.apache.cassandra.repair.Validator
-
- Component - Class in org.apache.cassandra.io.sstable
-
SSTables are made up of multiple components in separate files.
- Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component(Component.Type, String) - Constructor for class org.apache.cassandra.io.sstable.Component
-
- Component.Type - Enum in org.apache.cassandra.io.sstable
-
- COMPONENT_DATA - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_DIGEST - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_FILTER - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_INDEX - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPONENT_STATS - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- componentCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Returns the number of component already added to this builder.
- componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- componentIndex - Variable in class org.apache.cassandra.config.ColumnDefinition
-
- components - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- componentsCount() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
The number of subcomponents this type has.
- componentsCount() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- componentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Discovers existing components for the descriptor.
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
Deconstructs a composite type to a Tuple.
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- CompositesIndex - Class in org.apache.cassandra.db.index.composites
-
Base class for secondary indexes where composites are involved.
- CompositesIndex() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex
-
- CompositesIndex.IndexedEntry - Class in org.apache.cassandra.db.index.composites
-
- CompositesIndex.IndexedEntry(DecoratedKey, ByteBuffer, long, ByteBuffer, ColumnNameBuilder) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- CompositesIndexOnClusteringKey - Class in org.apache.cassandra.db.index.composites
-
Index on a CLUSTERING_KEY column definition.
- CompositesIndexOnClusteringKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- CompositesIndexOnPartitionKey - Class in org.apache.cassandra.db.index.composites
-
Index on a PARTITION_KEY column definition.
- CompositesIndexOnPartitionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- CompositesIndexOnRegular - Class in org.apache.cassandra.db.index.composites
-
Index on a REGULAR column definition on a composite type.
- CompositesIndexOnRegular() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- CompositesSearcher - Class in org.apache.cassandra.db.index.composites
-
- CompositesSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.composites.CompositesSearcher
-
- compositesToGroup - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- CompositeType - Class in org.apache.cassandra.db.marshal
-
- CompositeType.Builder - Class in org.apache.cassandra.db.marshal
-
- CompositeType.Builder(CompositeType) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- compress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- CompressedInputStream - Class in org.apache.cassandra.streaming.compress
-
InputStream which reads data from underlining source with given
CompressionInfo
.
- CompressedInputStream(InputStream, CompressionInfo, boolean) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- CompressedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
-
CRAR extends RAR to transparently uncompress blocks from the file into RAR.buffer.
- CompressedRandomAccessReader(String, CompressionMetadata, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- CompressedSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
-
- CompressedSequentialWriter(File, String, boolean, CompressionParameters, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
-
Class to hold a mark to the position of the file
- CompressedSequentialWriter.CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
-
- CompressedStreamReader - Class in org.apache.cassandra.streaming.compress
-
StreamReader that reads from streamed compressed SSTable
- CompressedStreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressedStreamWriter - Class in org.apache.cassandra.streaming.compress
-
StreamWriter for compressed SSTable.
- CompressedStreamWriter(SSTableReader, Collection<Pair<Long, Long>>, CompressionInfo, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamWriter
-
- CompressedThrottledReader - Class in org.apache.cassandra.io.compress
-
- CompressedThrottledReader(String, CompressionMetadata, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- compression - 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
-
- COMPRESSION_PARAMETERS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- CompressionInfo - Class in org.apache.cassandra.streaming.compress
-
Container that carries compression parameters and chunks to decompress data from stream.
- CompressionInfo(CompressionMetadata.Chunk[], CompressionParameters) - Constructor for class org.apache.cassandra.streaming.compress.CompressionInfo
-
- compressionInfo - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- CompressionMetadata - Class in org.apache.cassandra.io.compress
-
Holds metadata about compressed file
- CompressionMetadata.Chunk - Class in org.apache.cassandra.io.compress
-
Holds offset and length of the file chunk
- CompressionMetadata.Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- CompressionMetadata.Writer - Class in org.apache.cassandra.io.compress
-
- compressionParameters - Variable in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters(CompressionParameters) - Method in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters() - Method in class org.apache.cassandra.config.CFMetaData
-
- compressionParameters - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompressionParameters - Class in org.apache.cassandra.io.compress
-
- CompressionParameters(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- compressionRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Current compression ratio for all SSTables
- compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- computeNext() - Method in class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
-
- computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
Find the next TreeRange.
- concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- concurrent_compactors - Variable in class org.apache.cassandra.config.Config
-
- concurrent_reads - Variable in class org.apache.cassandra.config.Config
-
- concurrent_replicates - Variable in class org.apache.cassandra.config.Config
-
- concurrent_writes - Variable in class org.apache.cassandra.config.Config
-
- 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 - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- conditions - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- conf - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- conf - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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.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
-
- ConfigurationException - Exception in org.apache.cassandra.exceptions
-
- ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationLoader - Interface in org.apache.cassandra.config
-
- confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
-
Establish a thrift connection to cassandra instance
- connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- Connection - Class in org.apache.cassandra.transport
-
- Connection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
-
- connection - Variable in class org.apache.cassandra.transport.Message
-
- connection() - Method in class org.apache.cassandra.transport.Message
-
- connection - Variable in class org.apache.cassandra.transport.SimpleClient
-
- Connection.Factory - Interface in org.apache.cassandra.transport
-
- Connection.Tracker - Interface in org.apache.cassandra.transport
-
- connectionComplete(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
The connection associated with @param socket is permanently finished.
- ConnectionHandler - Class in org.apache.cassandra.streaming
-
ConnectionHandler manages incoming/outgoing message exchange for the
StreamSession
.
- ConnectionMetrics - Class in org.apache.cassandra.metrics
-
- ConnectionMetrics(InetAddress, OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.metrics.ConnectionMetrics
-
Create metrics for given connection pool.
- consistency - Variable in class org.apache.cassandra.cql.BatchStatement
-
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- consistency - Variable in class org.apache.cassandra.thrift.Cassandra.execute_cql3_query_args
-
- consistency - Variable in class org.apache.cassandra.thrift.Cassandra.execute_prepared_cql3_query_args
-
- consistency - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- 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
-
- ConsistencyLevel - Enum in org.apache.cassandra.db
-
- consistencyLevel - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- 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.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
-
- Constants.Deleter - Class in org.apache.cassandra.cql3
-
- Constants.Deleter(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
-
- Constants.Literal - Class in org.apache.cassandra.cql3
-
- Constants.Marker - Class in org.apache.cassandra.cql3
-
- Constants.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
-
- Constants.Setter - Class in org.apache.cassandra.cql3
-
- Constants.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
-
- Constants.Substracter - Class in org.apache.cassandra.cql3
-
- Constants.Substracter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
-
- Constants.Type - Enum in org.apache.cassandra.cql3
-
- Constants.Value - Class in org.apache.cassandra.cql3
-
A constant value, i.e.
- Constants.Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
-
- construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Constructs an instance of the given class, which must have a no-arg or default constructor.
- contains(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Check to see if a certain ReplayPosition is contained by this segment file.
- contains(RowPosition) - Method in class org.apache.cassandra.db.DataRange
-
- contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.Bounds
-
- contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
-
- contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- contains(T) - Method in class org.apache.cassandra.dht.Range
-
Helps determine if a given point on the DHT ring is contained
in the range in question.
- containsBindMarker() - Method in class org.apache.cassandra.cql3.AbstractMarker
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
-
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
-
- containsBindMarker() - Method in interface org.apache.cassandra.cql3.Term
-
Whether or not that term contains at least one bind marker.
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- containsCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- containsKey(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- containsKey(K) - Method in interface org.apache.cassandra.cache.ICache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- containsKey(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsKey(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- containsValue(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- contents() - Method in class org.apache.cassandra.db.Memtable
-
- contentSerializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- context - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- contextManager - Static variable in class org.apache.cassandra.db.CounterColumn
-
- controller - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- convertOldStrategyName(String) - Static method in class org.apache.cassandra.config.KSMetaData
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is part of IFailureDetectionEventListener interface.
- convict(InetAddress, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
-
Convict the specified endpoint.
- convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
-
- convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
called from gossiper when it notices a node is not responding.
- convict(InetAddress, double) - Method in class org.apache.cassandra.repair.RepairSession
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.streaming.StreamSession
-
- coordinator - Variable in class org.apache.cassandra.tracing.TraceState
-
- coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- coordinatorScanLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- copy() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Clone this builder.
- copy() - Method in class org.apache.cassandra.db.DeletionInfo
-
- copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- copy() - Method in class org.apache.cassandra.db.ReadCommand
-
- copy() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
-
- copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
- copy() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- copyWithNewSSTableLevel(SSTableMetadata, int) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
Deprecated.
- CorruptBlockException - Exception in org.apache.cassandra.io.compress
-
- CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
-
- CorruptSSTableException(Exception, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- CorruptSSTableException(Exception, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- count(Column, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- count(Column, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
-
- count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The total number of bytes initially available in the byte array
buf
.
- count - Variable in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
The number of bytes written.
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- count() - Method in class org.apache.cassandra.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.SliceRange
-
- count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- countAll(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- countAllBatches() - Method in class org.apache.cassandra.db.BatchlogManager
-
- countAllBatches() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
Counts all batches currently in the batchlog.
- countCQL3Rows() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.PagedRangeCommand
-
- countCQL3Rows - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- countCQL3Rows() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- counter_column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
-
- COUNTER_ID_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- 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
-
- CounterColumn - Class in org.apache.cassandra.db
-
A column that represents a partitioned counter.
- CounterColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, long, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- CounterColumn(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
-
- 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).
- counterid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- CounterId - Class in org.apache.cassandra.utils
-
- CounterId.CounterIdRecord - Class in org.apache.cassandra.utils
-
- CounterId.CounterIdRecord(CounterId, long) - Constructor for class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- CounterId.OneShotRenewer - Class in org.apache.cassandra.utils
-
- CounterId.OneShotRenewer() - Constructor for class org.apache.cassandra.utils.CounterId.OneShotRenewer
-
- CounterIdCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CounterMutation - Class in org.apache.cassandra.db
-
- CounterMutation(RowMutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
-
- CounterMutationVerbHandler - Class in org.apache.cassandra.db
-
- CounterMutationVerbHandler() - Constructor for class org.apache.cassandra.db.CounterMutationVerbHandler
-
- CounterSerializer - Class in org.apache.cassandra.serializers
-
- CounterSerializer() - Constructor for class org.apache.cassandra.serializers.CounterSerializer
-
- 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.
- CounterUpdateColumn - Class in org.apache.cassandra.db
-
A counter update while it hasn't been applied yet by the leader replica.
- CounterUpdateColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
-
- CounterUpdateColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
-
- countPaged(String, String, ByteBuffer, SliceQueryFilter, ConsistencyLevel, int, long) - Static method in class org.apache.cassandra.service.pager.QueryPagers
-
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
- CQL3CasConditions - Class in org.apache.cassandra.cql3.statements
-
Processed CAS conditions on potentially multiple rows of the same partition.
- CQL3CasConditions(CFMetaData, long) - Constructor for class org.apache.cassandra.cql3.statements.CQL3CasConditions
-
- CQL3Type - Interface in org.apache.cassandra.cql3
-
- CQL3Type.Collection - Class in org.apache.cassandra.cql3
-
- CQL3Type.Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
-
- CQL3Type.Custom - Class in org.apache.cassandra.cql3
-
- CQL3Type.Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- CQL3Type.Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
-
- CQL3Type.Native - Enum in org.apache.cassandra.cql3
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
-
- CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- 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.
- CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
binded variable values) as CQL rows (and respective columns) in a given
ColumnFamily.
- CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- CqlPagingInputFormat - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- CqlPagingInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- CqlPagingRecordReader - Class in org.apache.cassandra.hadoop.cql3
-
Hadoop RecordReader read the values return from the CQL query
It use CQL key range query to page through the wide rows.
- CqlPagingRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- 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 - Class in org.apache.cassandra.cql
-
- CQLStatement(StatementType, Object, int) - Constructor for class org.apache.cassandra.cql.CQLStatement
-
- CQLStatement - Interface in org.apache.cassandra.cql3
-
- CqlStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
A row from a standard CF will be returned as nested tuples:
(((key1, value1), (key2, value2)), ((name1, val1), (name2, val2))).
- CqlStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
- CqlStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
- CRC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of CREATE USER query (also may be called on startup, see seedSuperuserOptions method).
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long) - Method in class org.apache.cassandra.cache.SerializingCacheProvider
-
- create(String, String) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- create(String, String) - Method in interface org.apache.cassandra.cql3.functions.Function.Factory
-
- create(List<Term>) - Static method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- create(Term) - Static method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- create(ByteBuffer, ByteBuffer, long, int, CFMetaData) - Static method in class org.apache.cassandra.db.Column
-
- create(String, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(int, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(boolean, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(double, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(ByteBuffer, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(InetAddress, long, String...) - Static method in class org.apache.cassandra.db.Column
-
- create(CFMetaData, boolean) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
Returns a (initially empty) column map whose columns are sorted
according to the provided comparator.
- create(CFMetaData) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String, String) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
-
- create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
- create() - Method in interface org.apache.cassandra.db.columniterator.IColumnIteratorFactory
-
- create(DataInput, ByteBuffer) - Static method in exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
-
- create(ColumnFamilyStore, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(ColumnFamilyStore, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- create(ByteBuffer, ByteBuffer, long, long, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.CounterColumn
-
- create(int, long, String...) - Static method in class org.apache.cassandra.db.DeletedColumn
-
- create(String, String) - Static method in class org.apache.cassandra.db.Directories
-
- create(ByteBuffer, ByteBuffer, long, int, int, int, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.ExpiringColumn
-
- create(ColumnFamilyStore, DataRange, List<IndexExpression>, int, boolean, long) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- create(ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- create(String, ByteBuffer, String, long, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.ReadCommand
-
- create(long, DeletionTime, ColumnIndex) - Static method in class org.apache.cassandra.db.RowIndexEntry
-
- create(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Create metadata about given compressed file including uncompressed data length, chunk size
and list of the chunk offsets of the compressed data.
- create(Map<? extends CharSequence, ? extends CharSequence>) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(Collection<SSTableWriter>) - Method in class org.apache.cassandra.streaming.StreamLockfile
-
- create(Message.Type, int, int, EnumSet<Frame.Header.Flag>, ChannelBuffer) - Static method in class org.apache.cassandra.transport.Frame
-
- create(C, C) - Static method in class org.apache.cassandra.utils.Interval
-
- create(C, C, D) - Static method in class org.apache.cassandra.utils.Interval
-
- create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
-
- create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- create(BiMultiValMap<K, V>, Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
-
- createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Creates all storage-related directories.
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Connects to the given server:port and returns a client based on the given socket that points to the configured
keyspace, and is logged in with the configured credentials.
- createClusteringPrefixBuilder(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- createCollector(AbstractType<?>) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- createCollector(Collection<SSTableReader>, AbstractType<?>, int) - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
create commutative column
- createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
create commutative column
- CreateColumnFamilyStatement - Class in org.apache.cassandra.cql
-
A CREATE COLUMNFAMILY
parsed from a CQL query statement.
- CreateColumnFamilyStatement(String) - Constructor for class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- createColumnFamilyStore(Keyspace, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, IPartitioner, CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- createCompactionStrategyInstance(ColumnFamilyStore) - Method in class org.apache.cassandra.config.CFMetaData
-
- createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createFilter(int, IBitSet) - Method in class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
-
- createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- CreateIndexStatement - Class in org.apache.cassandra.cql
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(String, String, Term) - Constructor for class org.apache.cassandra.cql.CreateIndexStatement
-
- CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(CFName, String, ColumnIdentifier, IndexPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- createInRelation(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.Relation
-
- createInstance(ColumnFamilyStore, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
This is the primary way to create a secondary index instance for a CF column.
- createKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, KSPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- createLinks(String) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- createLocal(long, Allocator) - 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.PagedRangeCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RangeSliceReply
-
- createMessage() - Method in class org.apache.cassandra.db.ReadCommand
-
- createMessage() - Method in class org.apache.cassandra.db.RowMutation
-
- createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.RowMutation
-
- createMessage() - Method in class org.apache.cassandra.db.SnapshotCommand
-
- createMessage() - Method in class org.apache.cassandra.db.TruncateResponse
-
- createMessage() - Method in class org.apache.cassandra.db.Truncation
-
- createMessage() - Method in class org.apache.cassandra.db.WriteResponse
-
- createMessage() - Method in class org.apache.cassandra.repair.messages.RepairMessage
-
- createMessage(boolean, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
Create serialized message.
- createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- createMetricName(String) - Method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
-
- createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
-
Create MetricName
from given metric name.
- createReader(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
-
- createReader(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- createReader(String) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- createRemote(CounterId, long, long, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single remote shard.
- createReplicationStrategy(KSMetaData) - Method in class org.apache.cassandra.db.Keyspace
-
- createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Called at query time
Creates a implementation specific searcher instance for this index type
- createShuffleBatchInsert(Collection<String>, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.Shuffle
-
Create and return a CQL batch insert statement for a set of token relocations.
- createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
-
- createSSTableAndLengthPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- CreateTableStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE TABLE
parsed from a CQL query statement.
- CreateTableStatement(CFName, CFPropDefs, boolean, Set<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- CreateTableStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTableStatement.RawStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createTracingSession() - Method in class org.apache.cassandra.service.QueryState
-
- CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateTriggerStatement(CFName, String, String) - Constructor for class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- CreateUserStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateUserStatement(String, UserOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- 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, int, SSTableReader) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
-
- createWriter(ColumnFamilyStore, long) - Method in class org.apache.cassandra.streaming.StreamReader
-
- creationTime() - Method in class org.apache.cassandra.db.Memtable
-
- credentials - Variable in class org.apache.cassandra.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
-
- CURRENT - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- current - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- current - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- current_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.io.sstable.Descriptor.Version
-
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
Streaming protocol version
- CURRENT_VERSION - Static variable in class org.apache.cassandra.transport.Server
-
current version of the native protocol we support
- currentBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
-
- currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentLimit() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- currentTasks - Variable in class org.apache.cassandra.db.Directories.DataDirectory
-
- CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
-
- 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
-
- CustomTNonBlockingServer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer(TNonblockingServer.Args) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- CustomTNonBlockingServer.CustomFrameBuffer - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer.CustomFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
-
- CustomTNonBlockingServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
-
- CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
-
Slightly modified version of the Apache Thrift TThreadPoolServer.
- CustomTThreadPoolServer(TThreadPoolServer.Args, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- CustomTThreadPoolServer.Factory - Class in org.apache.cassandra.thrift
-
- CustomTThreadPoolServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
-
- factory(Function) - Static method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
Creates a trivial factory that always return the provided function.
- factory - Static variable in class org.apache.cassandra.cql3.functions.TokenFct
-
- factory - Static variable in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- factory - Static variable in class org.apache.cassandra.db.AtomicSortedColumns
-
- factory - Static variable in class org.apache.cassandra.db.EmptyColumns
-
- factory - Static variable in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- factory - Static variable in class org.apache.cassandra.db.UnsortedColumns
-
- 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.LatencyMetrics
-
- fail() - Method in class org.apache.cassandra.repair.Validator
-
Called when some error during the validation happened.
- 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
-
- FailureDetectorMBean - Interface in org.apache.cassandra.gms
-
- 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
.
- FastByteArrayOutputStream - Class in org.apache.cassandra.io.util
-
A specialized OutputStream
for class for writing content to an
(internal) byte array.
- FastByteArrayOutputStream() - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Constructs a new ByteArrayOutputStream with a default size of 32 bytes.
- FastByteArrayOutputStream(int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Constructs a new ByteArrayOutputStream
with a default size of
size
bytes.
- FBUtilities - Class in org.apache.cassandra.utils
-
- FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
-
- fcntl(int, int, long) - Static method in class org.apache.cassandra.utils.CLibrary
-
- 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.
- fetchSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Fetches an empty segment file.
- 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_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.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.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
-
- fifteenMinuteRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Returns the 15-minute rate in terms of events per second.
- 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
-
- FileDataInput - Interface in org.apache.cassandra.io.util
-
- 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, long, List<Pair<Long, Long>>, CompressionInfo) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- filename - Variable in class org.apache.cassandra.cli.CliSessionState
-
- 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
-
- files - Variable in class org.apache.cassandra.streaming.StreamSummary
-
Number of files to transfer.
- fileSent(FileMessageHeader) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after sending FileMessageHeader.
- FileUtils - Class in org.apache.cassandra.io.util
-
- FileUtils() - Constructor for class org.apache.cassandra.io.util.FileUtils
-
- 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
-
- 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
-
- filterSSTablesForReads(List<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Filters SSTables that are to be blacklisted from the given collection
- filterToSC(CompositeType, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- finalizeHeader(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- finalizeMetadata(String, double) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- finalState - Variable in class org.apache.cassandra.streaming.StreamException
-
- 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_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.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.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_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.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.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_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.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.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
- findSupportingVersion(SemanticVersion...) - Method in class org.apache.cassandra.utils.SemanticVersion
-
Returns a version that is backward compatible with this version amongst a list
of provided version, or null if none can be found.
- finish - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- finish() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- finish - Variable in class org.apache.cassandra.thrift.SliceRange
-
- finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
-
- 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
-
- finished() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
remove the event complete
- finishShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
- finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- first - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- firstGroup() - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- firstKeyBeyond(RowPosition) - Method in class org.apache.cassandra.io.sstable.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
-
- 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
-
- flag - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- flags - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- 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
-
- flush() - Method in class org.apache.cassandra.db.Keyspace
-
- flush() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- flush() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
If buffer is dirty, flush it's contents to the operating system.
- flushAndSignal(CountDownLatch, Future<ReplayPosition>) - Method in class org.apache.cassandra.db.Memtable
-
- 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.SequentialWriter
-
Override this method instead of overriding flush()
- flushIndexesBlocking() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Flush all indexes to disk
- 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
-
- fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- 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(CounterId.OneShotRenewer) - 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.SSTableReader
-
For testing purposes only.
- forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Trigger a cleanup of keys on a single keyspace
- forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compaction of a single keyspace
- forceKeyspaceCompaction(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
-
- forceKeyspaceRepair(String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
Trigger proactive repair for a keyspace and column families.
- forceKeyspaceRepair(Range<Token>, String, boolean, Collection<String>, Collection<String>, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceRepair(String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Triggers proactive repair for given column families, or all columnfamilies for the given keyspace
if none are explicitly listed.
- forceKeyspaceRepair(String, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceRepairPrimaryRange(String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceRepairPrimaryRange(String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Triggers proactive repair but only for the node primary range.
- forceKeyspaceRepairPrimaryRange(String, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceKeyspaceRepairRange(String, String, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceRepairRange(String, Collection<Range<Token>>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceRepairRange(String, String, String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Perform repair of a specific range.
- forceKeyspaceRepairRange(String, String, String, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceMajorCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
force a major compaction of this column family
- 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, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, boolean, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- forceRepairAsync(String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- forceRepairAsync(PrintStream, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairRangeAsync(String, String, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Same as forceRepairAsync, but handles a specified range
- forceRepairRangeAsync(String, String, String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Same as forceRepairAsync, but handles a specified range
- forceRepairRangeAsync(PrintStream, String, boolean, Collection<String>, Collection<String>, String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceShutdown() - Method in class org.apache.cassandra.repair.RepairSession
-
clear all RepairJobs and terminate this session.
- forceTerminateAllRepairSessions() - Method in class org.apache.cassandra.service.StorageService
-
- forceTerminateAllRepairSessions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- 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(List<CFDefinition.Name>) - Static method in class org.apache.cassandra.cql3.statements.Selection
-
- forExternalCalls(SocketAddress) - Static method in class org.apache.cassandra.service.ClientState
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.ClientState
-
- forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
-
- forKey(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.RowPosition
-
- forKeyRange(Range<Token>) - Static method in class org.apache.cassandra.db.DataRange
-
- format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- 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
-
- FORWARD_FROM - Static variable in class org.apache.cassandra.db.RowMutation
-
- FORWARD_TO - Static variable in class org.apache.cassandra.db.RowMutation
-
- 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.Compressor() - Constructor for class org.apache.cassandra.transport.Frame.Compressor
-
- Frame.Decoder - Class in org.apache.cassandra.transport
-
- Frame.Decoder(Connection.Factory) - Constructor for class org.apache.cassandra.transport.Frame.Decoder
-
- Frame.Decompressor - Class in org.apache.cassandra.transport
-
- Frame.Decompressor() - Constructor for class org.apache.cassandra.transport.Frame.Decompressor
-
- Frame.Encoder - Class in org.apache.cassandra.transport
-
- Frame.Encoder() - Constructor for class org.apache.cassandra.transport.Frame.Encoder
-
- 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
-
- FramedTransportFactory - Class in org.apache.cassandra.cli.transport
-
- FramedTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.FramedTransportFactory
-
- free(long) - Method in interface org.apache.cassandra.io.util.IAllocator
-
- free(long) - Method in class org.apache.cassandra.io.util.JEMallocAllocator
-
- free(long) - Method in interface org.apache.cassandra.io.util.JEMallocAllocator.JEMLibrary
-
- free() - Method in class org.apache.cassandra.io.util.Memory
-
- free(long) - Method in class org.apache.cassandra.io.util.NativeAllocator
-
- freshSegment() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- 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
-
- fromByte(byte) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
- fromByte(byte) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
- fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- fromBytes(ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
-
- fromCode(int) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
- 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
-
- 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 "/-[tmp-][-]-",
- fromFilename(String) - 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 "--[tmp-][-]-"
- 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.
- fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromName(String) - Static method in class org.apache.cassandra.auth.DataResource
-
Parses a data resource name into a DataResource instance.
- fromOpcode(int, Message.Direction) - Static method in enum org.apache.cassandra.transport.Message.Type
-
- fromProtocolV1(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
-
- fromSCFilter(CompositeType, ByteBuffer, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSchema(UntypedResultSet.Row) - Static method in class org.apache.cassandra.config.CFMetaData
-
Deserialize CF metadata from low-level representation
- fromSchema(Row, CFMetaData) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
Deserialize columns from storage-level representation
- fromSchema(Row, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize only Keyspace attributes without nested ColumnFamilies
- fromSchema(Row, Row) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize Keyspace with nested ColumnFamilies
- fromSchema(Row) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
Deserialize triggers from storage-level representation.
- fromSCNamesFilter(CompositeType, ByteBuffer, NamesQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSCSliceFilter(CompositeType, ByteBuffer, SliceQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- fromSelectors(CFDefinition, List<RawSelector>) - Static method in class org.apache.cassandra.cql3.statements.Selection
-
- fromSerialized(ByteBuffer, ListType) - Static method in class org.apache.cassandra.cql3.Lists.Value
-
- fromSerialized(ByteBuffer, MapType) - Static method in class org.apache.cassandra.cql3.Maps.Value
-
- fromSerialized(ByteBuffer, SetType) - Static method in class org.apache.cassandra.cql3.Sets.Value
-
- fromSerializedValue(byte) - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
- fromString(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
-
- 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.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
-
- 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.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.TimestampType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- 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
-
- fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
for compatibility with TimeUUID in CQL2.
- fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromThrift(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
-
- fromThrift(ColumnDef, boolean) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- fromThrift(List<ColumnDef>, boolean) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- fromThrift(TriggerDef) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- fromThrift(List<TriggerDef>) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThriftCqlRow(CqlRow) - Static method in class org.apache.cassandra.config.CFMetaData
-
Create CFMetaData from thrift
CqlRow
that contains columns from schema_columnfamilies.
- fromType(AbstractType) - Static method in enum org.apache.cassandra.transport.DataType
-
- fromValue(int) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
- FSError - Error in org.apache.cassandra.io
-
- FSError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
-
- 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
-
- fsync(int) - Static method in class org.apache.cassandra.utils.CLibrary
-
- fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
-
The top level range that this MerkleTree covers.
- FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- Function - Interface in org.apache.cassandra.cql3.functions
-
- Function.Factory - Interface in org.apache.cassandra.cql3.functions
-
- FunctionCall - Class in org.apache.cassandra.cql3.functions
-
- FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
-
- FunctionCall.Raw(String, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- functionName - Variable in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- Functions - Class in org.apache.cassandra.cql3.functions
-
- 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
-
- gcBefore(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
-
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
-
- gcBefore - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- gcBefore - Variable in class org.apache.cassandra.repair.Validator
-
- gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- GCInspector - Class in org.apache.cassandra.service
-
- GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
-
- GE - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- generate() - Static method in class org.apache.cassandra.utils.CounterId
-
- generateCFMetadataUpdate() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
- get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- get(K) - Method in interface org.apache.cassandra.cache.ICache
-
- get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- get(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- get(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CFDefinition
-
- get(int) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
- get() - Method in class org.apache.cassandra.cql3.Constants.Value
-
- get(String, List<? extends AssignementTestable>, ColumnSpecification) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- get() - Method in class org.apache.cassandra.cql3.Lists.Value
-
- get() - Method in class org.apache.cassandra.cql3.Maps.Value
-
- get() - Method in class org.apache.cassandra.cql3.Sets.Value
-
- get() - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- get(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- get(String, String) - Static method in class org.apache.cassandra.locator.SnitchProperties
-
Get a snitch property value or return null if not defined.
- get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
-
- get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- get() - Method in class org.apache.cassandra.service.AbstractReadExecutor
-
wait for an answer.
- get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- get(String) - Method in class org.apache.cassandra.service.FileCacheService
-
- get() - Method in class org.apache.cassandra.service.ReadCallback
-
- get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- get(byte) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- get(ByteBuffer, ColumnPath, ConsistencyLevel, 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(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(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(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.
- 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(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(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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
-
Deprecated.
use get_range_slices instead with range.row_filter specified
- get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- 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
-
- getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the current number of running tasks
- getActiveSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getActiveSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getActiveSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
- getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a milliseconds-since-epoch value for a type-1 UUID.
- getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAllDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
-
- getAllDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the list of all data file locations from conf
- getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getAllMemtables() - Method in class org.apache.cassandra.db.DataTracker
-
- getAllMemtablesLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
-
Get all ranges that span the ring given a set
of tokens.
- getAllSSTables() - Method in class org.apache.cassandra.db.Keyspace
-
- getAncestors() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds type information from @param bb to @param sb.
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getAndReferenceOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
like getOverlappingSSTables, but acquires references before returning
- getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
-
- getApplicationStateMap() - Method in class org.apache.cassandra.gms.EndpointState
-
Deprecated.
- getApproximateKeyCount(Iterable<SSTableReader>, CFMetaData) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
- getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
You should almost never use this.
- getArrayHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getArraySize(int, long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory an array will consume
- getArraySize(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte array consumes
- getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
-
- 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.ISaslAwareAuthenticator.SaslAuthenticator
-
- getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthenticator() - Method in class org.apache.cassandra.transport.ServerConnection
-
- 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
-
- getBackingFiles() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
-
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getBaseComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getBatchlogMutationFor(Collection<RowMutation>, UUID) - Static method in class org.apache.cassandra.db.BatchlogManager
-
- getBatchlogReplayThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
-
- getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- getBloom_filter_fp_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
- getBloomFilter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.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
-
- 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) - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of the names of the built column indexes for current store
- getBuiltIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getByte(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getByteBuffer(AbstractType<?>, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer according to a
comparator/validator.
- getByteBuffer() - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer.
- getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getBytesRead() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCachePath(String, String, String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCaching() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCaching() - Method in class org.apache.cassandra.thrift.CfDef
-
- getCanonicalPath(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCanonicalPath(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getCasContentionTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getCassandraServer() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getCF(UUID) - Method in class org.apache.cassandra.config.Schema
-
- 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() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCfDefinition(String, String, Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get CFDefinition of a column family
- getCFDirectories() - Method in class org.apache.cassandra.db.Directories
-
- getCfInfo(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the columnfamily definition for the signature
- getCfInfo(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return the CfInfo for the column family
- getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
-
Given a keyspace name & column family name, get the column family
meta data.
- getCFMetaData(UUID) - Method in class org.apache.cassandra.config.Schema
-
Get ColumnFamily metadata by its identifier
- getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
-
- getCFMetaData(String) - Method in class org.apache.cassandra.cql.AlterTableStatement
-
- getCFMetaData(String, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getCFMetaData(String, String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Validate that keyspace
is an existing keyspace and cfName
one of its existing column family.
- 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
-
- getCfNamesByKeySpace(KsDef) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns set of column family names in specified keySpace.
- getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getChunksForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- getClauseRelations() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getClauseRelations() - Method in class org.apache.cassandra.cql.WhereClause
-
- 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
-
- getClientEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClientFromInputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientFromOutputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClientState() - Method in class org.apache.cassandra.service.QueryState
-
- getClientTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getClosingString() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Bounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- getClosingString() - Method in class org.apache.cassandra.dht.Range
-
- getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getClusterName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the name of the cluster
- getClusterName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the name of the cluster
- getClusterName() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCollectedCount() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- getCollection(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- getCollectionElementValue() - Method in class org.apache.cassandra.cql3.ColumnCondition.WithVariables
-
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getCollectionType() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
-
Get a column given its name, returning null if the column is not
present.
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- 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_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_type() - Method in class org.apache.cassandra.thrift.CfDef
-
- getColumnComparator(AbstractType<?>) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getColumnComparator(AbstractType<?>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnComparator(AbstractType<?>) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnCount() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the number of columns in this map.
- getColumnCount() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumnCount() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns the ColumnDefinition for name
.
- getColumnDefinitionComparator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionForIndex(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- getColumnDefinitionFromColumnName(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
Returns a ColumnDefinition given a full (internal) column name.
- getColumnDefs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilies() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamily() - Method in class org.apache.cassandra.auth.DataResource
-
- getColumnFamily(Tree, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily(String, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column family namespace.
- getColumnFamily() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
-
- getColumnFamily(DecoratedKey, ByteBuffer, ByteBuffer, boolean, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
get a list of columns starting from a given column, in a specified order.
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
-
- getColumnFamily(UUID) - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.RowMutation
-
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given columnFamily
matching the Filter criteria in sorted order.
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getColumnFamilyIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getColumnFamilyIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getColumnFamilyName() - Method in class org.apache.cassandra.db.ReadCommand
-
- getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStore(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
-
- getColumnFamilyType(String, String) - Method in class org.apache.cassandra.config.Schema
-
Get type of the ColumnFamily but it's keyspace/name
- getColumnFamilyWithColumns(ColumnFamily.Factory) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getColumnFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getColumnMeta(Cassandra.Client, boolean, boolean) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get column meta data
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get a list of columns
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
get a list of column for the column family
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
include key columns
- getColumnName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column name to index.
- getColumnNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getColumnNames() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnNames() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnNames() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterable with the names of columns in this column map in the same order
as the underlying columns themselves.
- getColumnNames() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getColumnNames() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getColumnRelations() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnRelations() - Method in class org.apache.cassandra.cql.WhereClause
-
- getColumns() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumns() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- 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
-
- 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
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnsList() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- 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(Iterable<Column>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getColumnValues() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getCommandCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- getCommandDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- getComment() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the commit log
- getCommitLogPeriodicQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSegmentSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
size of commitlog segments to allocate
- getCommitLogSync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSyncBatchWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSyncPeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactedRow(List<SSTableIdentityIterator>) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getCompactedRow(SSTableIdentityIterator) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
convenience method for single-sstable compactions
- getCompacting() - Method in class org.apache.cassandra.db.DataTracker
-
- 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
-
- 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
-
- getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- getCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactions() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction objects.
- getCompactions() - Static method in class org.apache.cassandra.metrics.CompactionMetrics
-
- getCompactionStrategy() - Method in class org.apache.cassandra.cql3.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
-
Gets the compaction strategy class name
- getCompactionSummary() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompactionSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
List of running compaction summary strings.
- getCompactionTask(Collection<SSTableReader>, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getCompactionTask(Collection<SSTableReader>, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getComparator(String, String) - Method in class org.apache.cassandra.config.Schema
-
Get column comparator for ColumnFamily but it's keyspace/name
- getComparator() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getComparator(String) - Method in class org.apache.cassandra.cql.SelectStatement
-
- getComparator(String) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getComparator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getComparator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Adds DynamicCompositeType type information from @param bb1 to @param bb2.
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getComparator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getComparator(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- 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 interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getComponent(int) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
Returns the ith component added to this builder.
- getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- getComponentComparator(Integer, ColumnDefinition.Type) - Method in class org.apache.cassandra.config.CFMetaData
-
- getComponents() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Return a list of the "subcomponents" this type has.
- getComponents() - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- getCompressedBuilder() - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- 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.SSTableReader
-
Returns the compression metadata for this sstable.
- 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.db.ColumnFamilyStore
-
- getCompressionRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCompressor() - Method in class org.apache.cassandra.transport.Connection
-
- getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentReplicators() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- 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
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.Attributes
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
Returns the consistency level of this UPDATE
statement, either
one parsed from the CQL statement, or the default level otherwise.
- 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
-
Deprecated.
Returns core pool size of thread pool.
- getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of validation thread pool
- getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- 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.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
-
- getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- getCQL2KeyName() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLVersion() - Method in class org.apache.cassandra.service.ClientState
-
- getCrcCheckChance() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- getCredentialsSize() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
-
- 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
-
- getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
-
- getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return the generation value for this node.
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCurrentLocalCounterId() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Read the current local node id from the system keyspace or null if no
such node id is recorded.
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCurrentlyBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- getCurrentPosition() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getCurrentState() - Method in class org.apache.cassandra.streaming.StreamResultFuture
-
- getCurrentStreams() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getCurrentStreams() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
Returns the current state of all ongoing streams.
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the current contents of the buffer.
- getData() - Method in interface org.apache.cassandra.service.IResponseResolver
-
returns the data response without comparing with any digests
- getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDigestResolver
-
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String representing the datacenter this endpoint belongs to
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the data center for the endpoint, or UNKNOWN
if not known.
- getDatacenter() - Method in class org.apache.cassandra.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
-
- getDataTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Package protected for access from the CompactionManager.
- getDclocal_read_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
-
- getDcLocalReadRepair() - 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
-
- getDefaultIndexName(String, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
construct a map to store the mashaller type to cassandra data type mapping
- getDefaultTimeToLive() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDeletion() - Method in class org.apache.cassandra.thrift.Mutation
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- getDirectories() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Get sstable directories for the CF.
- getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
-
- getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDiskFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDouble(String, Double) - Method in class org.apache.cassandra.cql3.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)
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.DataTracker
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
Get the amount of droppable tombstones
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getDroppedColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts for server lifetime
- getDroppedMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getDroppedMessages() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getElementIndex() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- 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_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_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
-
- 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) - 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
-
- 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
-
- getEndpointToHostIdMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndpointToRangesMap() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getEndpointToTokenMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getEntity() - Method in class org.apache.cassandra.cql.Relation
-
- getEntity() - Method in class org.apache.cassandra.cql3.Relation
-
- getEntryIterator(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.Memtable
-
- getEpSnitchProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
-
- getEstimatedAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
-
- getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getExceptionCount() - Method in class org.apache.cassandra.service.StorageService
-
- getExceptionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getExpectedWriteSize() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Get expected write size to determine which disk to use for this task.
- getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getExpressionComparator() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- 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.AtomicSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the factory used for this ISortedColumns implementation.
- getFactory() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getFactory() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getFactory() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
-
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
-
Get system file descriptor from FileDescriptor object.
- 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_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.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.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
-
- getFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a class consumes, including the object header and the size of the fields.
- 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_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(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(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
-
- getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getFilter(long, int, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFilter(long, double, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- getFinish() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getFinish() - Method in class org.apache.cassandra.thrift.SliceRange
-
- getFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getFirstEmptyKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFlushQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFullColumnFamily() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- getFullyExpiredSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getFullyExpiredSSTables(ColumnFamilyStore, Set<SSTableReader>, Set<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
Finds expired sstables
works something like this;
1.
- getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the full class name
- getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
- getGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
-
- getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
-
- getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHashBuckets(ByteBuffer, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
-
- getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
-
- getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- 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
-
- getHost() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the mapping of endpoint to host ID
- getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getId(String, String) - Method in class org.apache.cassandra.config.Schema
-
Lookup keyspace/ColumnFamily identifier
- getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getId() - Method in class org.apache.cassandra.repair.RepairSession
-
- getId() - Method in class org.apache.cassandra.thrift.CfDef
-
- getId() - Method in enum org.apache.cassandra.transport.DataType
-
- getId() - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- getIdentityFilter(DecoratedKey, String, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
return a QueryFilter object that includes every column in the row.
- getIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- getIndex_interval() - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Allow access to the underlying column family store if there is one
- getIndexComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the index comparator for index backed by CFS, or null.
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- getIndexedValue(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexes() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get a list of columns with defined index
- getIndexesBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesByNames(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesNotBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexExpressions(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
-
- getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Deprecated.
- getIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getIndexKeyFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the decoratedKey for a column value
- getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Index name (or null).
- getIndexName() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns IndexOperator from string representation
- getIndexOperator(Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
get the position in the index file to start scanning to find the given key (at most indexInterval keys away)
- getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexType(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get index type from string
- getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInitialTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInMemoryCompactionLimit() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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.AbstractCassandraStorage
-
- getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
may be null if unset
- getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMinSimultReqPerConnections(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
-
- getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(AbstractType...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ListType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(AbstractType<K>, AbstractType<V>) - Static method in class org.apache.cassandra.db.marshal.MapType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.SetType
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
-
- getInstance(TypeSerializer<K>, TypeSerializer<V>) - Static method in class org.apache.cassandra.serializers.MapSerializer
-
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.SetSerializer
-
- getInt(String, Integer) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInt(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getInternodeAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInValues() - Method in class org.apache.cassandra.cql3.Relation
-
- getIOWait() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- 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_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
-
- 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(Iterable<Memtable>, Collection<SSTableReader>, DataRange, ColumnFamilyStore, long) - Static method in class org.apache.cassandra.db.RowIteratorFactory
-
Get a row iterator over the provided memtables and sstables, between the provided keys
and filtered by the queryfilter.
- getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently bootstrapping into the ring.
- getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKey(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- getKey() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- 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_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
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.WhereClause
-
- getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
-
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyComponent(int) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyName() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getKeyNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- getKeys() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.WhereClause
-
- 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
-
- getKeySample(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySampleSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySet() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getKeysMeta(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
get keys meta data
- getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
-
- getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
-
- getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeyspace() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyspace() - Method in class org.apache.cassandra.cql3.CFName
-
- getKeyspace() - Method in class org.apache.cassandra.db.AbstractRangeCommand
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getKeyspace() - Method in class org.apache.cassandra.db.ReadCommand
-
- getKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getKeyspace() - Method in interface org.apache.cassandra.service.IReadCommand
-
- 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
-
- getKeySpaceDef(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliUtils
-
Parse the statement from cli and return KsDef
- getKeyspaceDefinitions() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Get keyspace instance by name
- getKeyspaceMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace inner ColumnFamilies
- getKeyspaceName() - Method in class org.apache.cassandra.db.CounterMutation
-
- getKeyspaceName() - Method in interface org.apache.cassandra.db.IMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.db.RowMutation
-
- getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
-
- getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
-
- getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
-
- getKeyStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyType() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getKeyType(String) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- 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.cli.CliClient
-
- getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace by its name
- getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
caller should not modify leavingEndpoints
- getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently leaving the ring.
- getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the length of the valid data currently in the buffer.
- getLengthInBytes() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
-
- getLevel(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelCount() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLevelSorted(int, Comparator<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getLifetimeReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLiveCellsPerSlice() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveCellsPerSlice() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.DataRange
-
- getLiveCount(ColumnFamily, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getLiveCount(IDiskAtomFilter, long) - Method in class org.apache.cassandra.db.Row
-
- getLiveDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLiveNaturalEndpoints(Keyspace, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
This method attempts to return N endpoints that are responsible for storing the
specified key i.e for replication.
- getLiveNaturalEndpoints(Keyspace, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of live nodes in the cluster, where "liveness" is
determined by the failure detector of the node being queried.
- getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLiveNodes() - Method in class org.apache.cassandra.tools.Shuffle
-
Return a list of the live nodes (using JMX).
- getLiveSize() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Get current amount of memory this index is consuming (in bytes)
- getLiveSize() - Method in class org.apache.cassandra.db.Memtable
-
- getLiveSortedEndpoints(Keyspace, ByteBuffer) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLoad() - Method in class org.apache.cassandra.service.StorageService
-
raw load value
- getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- getLoadMap() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value.
- getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLoadString() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value
- getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
-
Please use getBroadcastAddress instead.
- getLocalComparator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.DeletedColumn
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getLocalDeletionTime() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- getLocalDeletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
-
- getLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Read the host ID from the system keyspace, creating (and storing) one if
none exists.
- getLocalHostId() - Method in class org.apache.cassandra.service.StorageService
-
- getLocalHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve this hosts unique ID
- getLocalHostId() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLocalId() - Static method in class org.apache.cassandra.utils.CounterId
-
- getLocalPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
-
- getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getLocationForDisk(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories
-
Returns SSTable location which is inside given data directory.
- getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getLong(long) - Method in class org.apache.cassandra.io.util.Memory
-
- getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.DeletedColumn
-
- getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getMax_compaction_threshold() - 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) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaximumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaximumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the maximum number of sstables in queue before compaction kicks off
- getMaximumCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getMaximumCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns maximum size of compaction thread pool
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Returns maximum pool size of thread pool.
- getMaximumValidatorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getMaximumValidatorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns size of validator thread pool
- getMaxLiveCount() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaxStreamingRetries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanColumns() - Method in class org.apache.cassandra.db.DataTracker
-
- getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
- 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.
- getMemtableAllocator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMemtableColumnIterator(Memtable) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getMemtableColumnsCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableColumnsCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableFlushPeriod() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.
- getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.DataTracker
-
- getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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.exceptions.RepairException
-
- getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception message.
- getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
-
- getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getMessageType() - Method in class org.apache.cassandra.net.MessageIn
-
- getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- getMetadata() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- getMetadata() - Method in interface org.apache.cassandra.io.util.ICompressedFile
-
- getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getMin_compaction_threshold() - 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
- getMinimumSize() - Method in class org.apache.cassandra.utils.Allocator
-
- getMinimumSize() - Method in class org.apache.cassandra.utils.HeapAllocator
-
- getMinimumSize() - Method in class org.apache.cassandra.utils.SlabAllocator
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getMinRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Endpoints which are migrating to the new tokens
- getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently moving in the ring.
- getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- getMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.BatchStatement
-
- getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getName() - Method in class org.apache.cassandra.auth.DataResource
-
- getName() - Method in interface org.apache.cassandra.auth.IResource
-
- getName() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Name of the column family to create
- getName() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getName() - Method in class org.apache.cassandra.db.Keyspace
-
- 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
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Return the unique name for this index and column
to be stored in the SystemKeyspace that tracks if each column is built
- getNamesFilter(DecoratedKey, String, SortedSet<ByteBuffer>, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getNativeTransportAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxFrameSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNativeTransportPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
get the (possibly cached) endpoints that should store the given Token.
- getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.LocalStrategy
-
We need to override this even if we override calculateNaturalEndpoints,
because the default implementation depends on token calculations but
LocalStrategy may be used before tokens are set up.
- getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
- getNaturalEndpoints(String, RingPosition) - Method in class org.apache.cassandra.service.StorageService
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
- getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getNeighbors(String, Range<Token>, 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.
- getNewInOrderSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNewSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
get next row
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
the only difference between background and maximal in LCS is that maximal is still allowed
(by explicit user request) even when compaction is disabled.
- getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getNextId() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
-
- getNextWide() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
read wide row
- getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
-
- getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
-
- getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
-
- getNonSystemKeyspaces() - Method in class org.apache.cassandra.config.Schema
-
- getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getNormalizedLoadAvg() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
-
- getNum() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Expert: gets the number of longs in the array that are in use
- getObjectHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getObjectPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getoffHeapMemoryAllocator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOldLocalCounterIds() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getOldLocalCounterIds() - Static method in class org.apache.cassandra.utils.CounterId
-
Return the list of old local counter id of this node.
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Return the current file pointer of the underlying on-disk file.
- getOnDiskIterator(DataInput, int, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskIterator(DataInput, int, ColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOp() - Method in class org.apache.cassandra.thrift.IndexExpression
-
- getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getOpeningString() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.Bounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- getOpeningString() - Method in class org.apache.cassandra.dht.Range
-
- getOperationMode() - Method in class org.apache.cassandra.service.StorageService
-
- getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
get the operational mode (leaving, joining, normal, decommissioned, client)
- getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getOperations() - Method in class org.apache.cassandra.db.Memtable
-
- getOperations() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getOptions() - Method in class org.apache.cassandra.cql3.UserOptions
-
- getOptions() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getOptionsSize() - Method in class org.apache.cassandra.thrift.TriggerDef
-
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- getOriginalRequestedCount() - Method in class org.apache.cassandra.db.SliceFromReadCommand
-
The original number of columns requested by the user.
- getOutboundBindAny() - Static method in class org.apache.cassandra.config.Config
-
- getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
The OutputCommitter for this format does not write any data to the DFS.
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCompressionParamaters(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
output format
- getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getOwnership() - Method in class org.apache.cassandra.service.StorageService
-
- getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
given a list of tokens (representing the nodes in the cluster), returns
a mapping from "token -> %age of cluster owned by that token"
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPageSize() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The pageSize for this query.
- getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The paging state for this query, or null if not relevant.
- getParent() - Method in class org.apache.cassandra.auth.DataResource
-
- getParent() - Method in interface org.apache.cassandra.auth.IResource
-
Gets next resource in the hierarchy.
- getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
-
- getPartitioner() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPartitioner(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
-
Return a partitioner instance for remote host.
- getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPartitionerName() - Method in class org.apache.cassandra.service.StorageService
-
Returns the cluster partitioner
- getPartitionerName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the cluster partitioner
- getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return partition keys
- getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getPath() - Method in class org.apache.cassandra.thrift.Cassandra.remove_counter_args
-
- getPathInfo() - Method in interface org.apache.cassandra.cache.CacheKey
-
- getPathInfo() - Method in class org.apache.cassandra.cache.KeyCacheKey
-
- getPathInfo() - Method in class org.apache.cassandra.cache.RowCacheKey
-
- getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
-
a mutable map may be returned but caller should not modify it
- getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of pending ranges to endpoints that describe the ring topology
- getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPigType(AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get pig type for the cassandra data type
- getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Get position updating key cache and stats.
- getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- getPosition() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
- getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- getPrefetchedList(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- getPreheatKeyCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrepared() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getPreparedForThrift(Integer) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getPrimaryRangeForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.
- getPrimaryRangesFor(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getPrimaryRangesForEndpoint(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Get the "primary ranges" for the specified keyspace and endpoint.
- getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- getProcessor(CassandraServer) - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getProperty(String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyBoolean(String, Boolean) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyDouble(String, Double) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyInt(String, Integer) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertySet(String, Set<String>) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyString(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getProtectedConstructor(Class, Class...) - Static method in class org.apache.cassandra.utils.Hex
-
Used to get access to protected/private constructor of the specified class
- getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Used to get access to protected/private field of the specified class
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The protocol version for the query.
- 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.AbstractCassandraStorage
-
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(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
-
- getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String repesenting the rack this endpoint belongs to
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
Return the rack for which an endpoint resides in
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
-
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the rack for the endpoint, or UNKNOWN
if not known.
- getRack() - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- getRack() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getRandomToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
-
- getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- getRange() - Method in class org.apache.cassandra.repair.RepairSession
-
- 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.
- getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeSlice(AbstractRangeCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
- getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToAddressMapInLocalDC(String) - Method in class org.apache.cassandra.service.StorageService
-
- getRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding listen addresses.
- getRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to end points that describe the ring topology
of a Cassandra cluster.
- getRangeToRpcaddressMap(String) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding RPC addresses for a given keyspace.
- getRangeToRpcaddressMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of range to rpc addresses that describe the ring topology
of a Cassandra cluster.
- getRateLimiter() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Gets compaction rate limiter.
- getRateLimiter() - Static method in class org.apache.cassandra.streaming.StreamManager
-
Gets streaming rate limiter.
- getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
-
- getRawOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- 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
-
- getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getReadExecutor(ReadCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
-
- getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getReadRepairAttempted() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairAttempted() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairAttempted() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBackground() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBlocking() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReceivedCount() - Method in class org.apache.cassandra.service.ReadCallback
-
- getReceivingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getReceivingStream(UUID) - Method in class org.apache.cassandra.streaming.StreamManager
-
- getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentHitRate() - Method in class org.apache.cassandra.metrics.CacheMetrics
-
Deprecated.
- getRecentLatency() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- getRecentLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getRecentLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
returns microseconds
- getRecentlyDropped() - Method in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
Deprecated.
- getRecentlyDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentlyDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts since last called
- getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentTimeout() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getRecentTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check per host.
- getRecentTotalTimeout() - Static method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTotalTimouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTotalTimouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check.
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
Get the RecordWriter
for the given task.
- getReduced() - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
- getReferenceSize() - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- getReferenceSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRelation(Bound, Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the Cassandra version.
- getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- getRelocatingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Ranges which are migrating to new endpoints.
- getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- 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
-
- getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplayPosition(Iterable<? extends SSTableReader>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
Convenience method to compute the replay position for a group of SSTables.
- getReplayPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getReplicateOnWrite() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
-
- getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- 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_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_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_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() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getReturnType(String, String, String) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Deprecated.
use reverseComparator field instead
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getReverseSortedColumns() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getRingVersion() - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- getRowCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getRpcMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcServerType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
-
- getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get location of the saved caches dir
- getSavedTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getScanner(DataRange) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
I/O SSTableScanner
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Returns a list of KeyScanners given sstables and a range on which to scan.
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getSchedulingValue() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getSchema(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
define the schema
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
schema: (value, value, value) where keys are in the front.
- getSchema() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getSchemaKSKey(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getSchemaVersion() - Method in class org.apache.cassandra.service.StorageService
-
- getSchemaVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the current Schema version.
- getSchemaVersion() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
-
- getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Returns each live node's schema version
- getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
-
- 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.CompressedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- getSendingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getSerial_consistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- getSerialConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
-
Serial consistency for conditional updates.
- getSerializedCachePath(String, String, CacheService.CacheType, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.BytesType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ListType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.LongType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- getServerEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
- getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
-
- getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
-
- getSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getSeverity() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSeverity() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- getSeverity(InetAddress) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- getShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getShortName(AbstractType<?>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- getSimple(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- 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
-
- getSize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte buffer consumes
- getSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- getSliceFilter(DecoratedKey, String, ByteBuffer, ByteBuffer, boolean, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
-
- getSnapshotSSTableReader(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSnitchName() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- getSnitchName() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the snitch name of the cluster
- getSocket(EncryptionOptions, InetAddress, int, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect
- getSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
Create a socket and connect, using any local address
- getSocket(EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
-
Just create a socket
- getSocket() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Returns a reference to the underlying socket.
- getSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns the columns of this column map as a collection.
- getSortedColumns() - Method in class org.apache.cassandra.db.EmptyColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- getSortedColumns() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
Sorts the Collection of node addresses by proximity to the given address
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a new List sorted by proximity to the given endpoint
- getSpecifications() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- 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, CFMetaData) - Method in class org.apache.cassandra.service.StorageService
-
- getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
Get an iterator that returns columns from the given SSTable using the opened file
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
returns an iterator that returns columns from the given SSTable
matching the Filter criteria in sorted order.
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.QueryFilter
-
- getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTableCountPerLevel() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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.DataTracker
-
- getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesForKey(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSstablesIterated() - Method in class org.apache.cassandra.db.CollationController
-
- getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
-
Retrieve a stage from the StageManager
- getStage() - Method in class org.apache.cassandra.net.MessageOut
-
- getStart() - Method in class org.apache.cassandra.cql.SelectExpression
-
- 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
-
- getStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getStatement(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- getStatements() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- getStaticColumnNameBuilder() - Method in class org.apache.cassandra.config.CFMetaData
-
- getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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
-
- getStrategyClass() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getStrategyOptions() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getStreamId() - Method in class org.apache.cassandra.transport.Message
-
- getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
- getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getString(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.Column
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.CounterColumn
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
get a string representation of the bytes suitable for log messages
- getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
- 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_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_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_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
-
- getSuperclassFieldPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
-
- getSuperClassFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a super class consumes, given the primitive field sizes
- getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- 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_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
-
- getText() - Method in class org.apache.cassandra.cql.Term
-
Returns the text parsed to create this term.
- getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getThriftClient(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
-
Setup and return a new Thrift RPC connection.
- 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_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.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.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.ReadCommand
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageIn
-
- getTimeout() - Method in class org.apache.cassandra.net.MessageOut
-
- getTimeout() - Method in interface org.apache.cassandra.service.IReadCommand
-
- getTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts per host
- getTimestamp(ThriftClientState) - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimestamp() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getTimestamp(long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimestamp(long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimestamp(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getTimestamp() - Method in class org.apache.cassandra.service.QueryState
-
This clock guarantees that updates for the same QueryState will be ordered
in the sequence seen, even if multiple updates happen in the same millisecond.
- 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
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getTimeToLive(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Attributes
-
- getTimeToLive(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getTimeToLive() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID).
- getTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Creates a type 1 UUID (time-based UUID) with the timestamp of @param when, in milliseconds.
- getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
-
Returns a 16 byte representation of a type 1 UUID (a time-based UUID),
based on the current system time.
- getTimeUUIDBytes(long) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a milliseconds-since-epoch timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a 100-nanoseconds precision timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getToken() - Method in class org.apache.cassandra.db.DecoratedKey
-
- getToken() - Method in class org.apache.cassandra.db.RowPosition
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
Generate the token of a key.
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToken() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getToken() - Method in class org.apache.cassandra.dht.Token
-
- getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthChallenge
-
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthSuccess
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
-
- getTokens(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getTokens(String) - Method in class org.apache.cassandra.service.StorageService
-
- getTokens() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for this node.
- getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for a specified node.
- getTokens() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of tokens to endpoints, including the bootstrapping
ones.
- getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- 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
- getTombstonesPerSlice() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTombstonesPerSlice() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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() - 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
-
- getTotalAllMemtablesLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalBatchesReplayed() - Method in class org.apache.cassandra.db.BatchlogManager
-
- getTotalBatchesReplayed() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
- getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getTotalBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks that had blocked before being accepted (or
rejected).
- getTotalBufferSize() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- getTotalBufferSize() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
- getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalBytesCompacted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCommitlogSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getTotalCommitlogSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCompactionsCompleted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTotalLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
- getTotalLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getTotalLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
-
returns microseconds
- getTotalLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getTotalMemtableLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalMemtableSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTask
-
- getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getTotalSizeReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeSent() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalSizeToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Total number of timeouts happened on this node
- getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
-
- getTracingProbability() - Method in class org.apache.cassandra.service.StorageService
-
- getTracingProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the configured tracing probability.
- getTracker() - Method in class org.apache.cassandra.transport.Connection
-
- getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.FramedTransportFactory
-
- getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.SSLTransportFactory
-
- getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- 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
-
- getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getTruncateRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getTruncationRecords() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getTruncationTime() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTtl() - Method in class org.apache.cassandra.thrift.Column
-
- getType() - Method in class org.apache.cassandra.cql.Term
-
Obtain the term's type.
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- getType() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- getType() - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- getType() - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.ListSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.LongSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.MapSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.SetSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- getType() - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- getType() - Method in class org.apache.cassandra.thrift.CqlResult
-
- getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
-
Get AbstractType by function name
- getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- 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_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
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.DataTracker
-
- getUncompactingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- getUnfinishedCompactions() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
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
-
- 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
-
- getUnsignedShort(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CollectionType
-
- getUnsignedShort(ByteBuffer) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
-
- getUnwritableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
-
- getUnwritableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
-
- getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- 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
-
- getUser() - Method in class org.apache.cassandra.service.ClientState
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getUsername() - Method in class org.apache.cassandra.cli.CliClient
-
- getUUID(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
-
creates a type 1 uuid from raw bytes.
- getValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
-
- getValidator() - Method in enum org.apache.cassandra.cli.CliClient.Function
-
- getValidator() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getValidator() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the validators
- getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- getValue() - Method in class org.apache.cassandra.cql.Relation
-
- getValue() - Method in class org.apache.cassandra.cql3.Relation
-
- getValue() - Method in class org.apache.cassandra.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.BatchQueryOptions
-
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- 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
-
- getValueValidatorFromColumnName(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
-
Like getColumnDefinitionFromColumnName, the argument must be an internal column/cell name.
- 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 class org.apache.cassandra.cql3.statements.BatchStatement.BatchOfPreparedVariables
-
- getVariablesForStatement(int) - Method in interface org.apache.cassandra.cql3.statements.BatchStatement.BatchVariables
-
- getVariablesForStatement(int) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.PreparedBatchVariables
-
- getVerbHandler(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
-
This method returns the verb handler associated with the registered
verb.
- getVersion() - Method in class org.apache.cassandra.config.Schema
-
- getVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- 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.DataTracker
-
- 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
-
- getWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- getWorkMap(Multimap<Range<Token>, InetAddress>) - Static method in class org.apache.cassandra.dht.RangeStreamer
-
- getWriteableLocation() - Method in class org.apache.cassandra.db.Directories
-
- getWriteableLocationAsFile() - Method in class org.apache.cassandra.db.Directories
-
- getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
retained for benefit of old tests
- getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getWriter() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- GLOBAL_OPTIONS - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- GossipDigest - Class in org.apache.cassandra.gms
-
Contains information about a specified list of Endpoints and the largest version
of the state they have generated as known by the local endpoint.
- GossipDigestAck - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestSynMessage by an
endpoint.
- GossipDigestAck2 - Class in org.apache.cassandra.gms
-
This ack gets sent out as a result of the receipt of a GossipDigestAckMessage.
- GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
-
- GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
-
- GossipDigestSyn - Class in org.apache.cassandra.gms
-
This is the first message that gets sent out as a start of the Gossip protocol in a
round.
- GossipDigestSyn(String, String, List<GossipDigest>) - Constructor for class org.apache.cassandra.gms.GossipDigestSyn
-
- GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
-
- GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
-
- Gossiper - Class in org.apache.cassandra.gms
-
This module is responsible for Gossiping information for the local endpoint.
- GossiperMBean - Interface in org.apache.cassandra.gms
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
called after Gossiper instance exists immediately before it starts gossiping
- gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Called in preparation for the initiation of the gossip loop.
- GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
-
- GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
-
- GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
-
- GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Grants a set of permissions on a resource to a user.
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- GrantStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.GrantStatement
-
- GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
-
- groups() - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
-
- GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- GuidGenerator - Class in org.apache.cassandra.utils
-
- GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
-
- guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- IAllocator - Interface in org.apache.cassandra.io.util
-
- IAsyncCallback<T> - Interface in org.apache.cassandra.net
-
implementors of IAsyncCallback need to make sure that any public methods
are threadsafe with respect to response() being called from the message
service.
- IAuthenticator - Interface in org.apache.cassandra.auth
-
- IAuthenticator.Option - Enum in org.apache.cassandra.auth
-
Supported CREATE USER/ALTER USER options.
- IAuthorizer - Interface in org.apache.cassandra.auth
-
Primary Cassandra authorization interface.
- IBitSet - Interface in org.apache.cassandra.utils.obs
-
- ICache<K,V> - Interface in org.apache.cassandra.cache
-
This is similar to the Map interface, but requires maintaining a given capacity
and does not require put or remove to return values, which lets SerializingCache
be more efficient by avoiding deserialize except on get.
- IColumnIteratorFactory - Interface in org.apache.cassandra.db.columniterator
-
- ICommitLogExecutorService - Interface in org.apache.cassandra.db.commitlog
-
Like ExecutorService, but customized for batch and periodic commitlog execution.
- ICompactionScanner - Interface in org.apache.cassandra.db.compaction
-
An ICompactionScanner is an abstraction allowing multiple SSTableScanners to be
chained together under the hood.
- ICompressedFile - Interface in org.apache.cassandra.io.util
-
- ICompressor - Interface in org.apache.cassandra.io.compress
-
- ICompressor.WrappedArray - Class in org.apache.cassandra.io.compress
-
A simple wrapper of a byte array.
- ICompressor.WrappedArray(byte[]) - Constructor for class org.apache.cassandra.io.compress.ICompressor.WrappedArray
-
- IContext - Interface in org.apache.cassandra.db.context
-
An opaque commutative context.
- IContext.ContextRelationship - Enum in org.apache.cassandra.db.context
-
- id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- id - Variable in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- id() - Method in class org.apache.cassandra.db.ColumnFamily
-
- id - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- id - Variable in exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
-
- id - Variable in class org.apache.cassandra.thrift.CfDef
-
- id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- id - Variable in class org.apache.cassandra.utils.CounterId.CounterIdRecord
-
- IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
-
- IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
-
Will read entire CF into memory.
- IDiskAtomFilter - Interface in org.apache.cassandra.db.filter
-
Given an implementation-specific description of what columns to look for, provides methods
to extract the desired columns from a Memtable, SSTable, or SuperColumn.
- IDiskAtomFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- IDiskAtomFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- IDLE_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
-
- IEndpointLifecycleSubscriber - Interface in org.apache.cassandra.service
-
Interface on which interested parties can be notified of high level endpoint
state changes.
- IEndpointSnitch - Interface in org.apache.cassandra.locator
-
This interface helps determine location of node in the data center relative to another node.
- IEndpointStateChangeSubscriber - Interface in org.apache.cassandra.gms
-
This is called by an instance of the IEndpointStateChangePublisher to notify
interested parties about changes in the the state associated with any endpoint.
- IExecutorMBean - Interface in org.apache.cassandra.concurrent
-
Deprecated.
- IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
-
Implemented by the Gossiper to convict an endpoint
based on the PHI calculated by the Failure Detector on the inter-arrival
times of the heart beats.
- IFailureDetector - Interface in org.apache.cassandra.gms
-
An interface that provides an application with the ability
to query liveness information of a node in the cluster.
- IFailureNotification - Interface in org.apache.cassandra.gms
-
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- ifile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- IFilter - Interface in org.apache.cassandra.utils
-
- ignored - Variable in class org.apache.cassandra.db.filter.ColumnCounter
-
- ignored() - Method in class org.apache.cassandra.db.filter.ColumnCounter
-
- ignoredSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- IInternodeAuthenticator - Interface in org.apache.cassandra.auth
-
- ILatencySubscriber - Interface in org.apache.cassandra.locator
-
- IMeasurableMemory - Interface in org.apache.cassandra.cache
-
- IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
-
- IMessageSink - Interface in org.apache.cassandra.sink
-
- IMigrationListener - Interface in org.apache.cassandra.service
-
- importJson(String, String, String, String) - Method in class org.apache.cassandra.tools.SSTableImport
-
Convert a JSON formatted file to an SSTable.
- IMutation - Interface in org.apache.cassandra.db
-
- in - Variable in class org.apache.cassandra.cli.CliSessionState
-
- in_memory_compaction_limit_in_mb - Variable in class org.apache.cassandra.config.Config
-
- includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- includes(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- includeStartKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- IncludingExcludingBounds<T extends RingPosition> - Class in org.apache.cassandra.dht
-
AbstractBounds containing only its left endpoint: [left, right).
- IncludingExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.IncludingExcludingBounds
-
- incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
-
- 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) - Constructor for class org.apache.cassandra.net.IncomingStreamingConnection
-
- IncomingTcpConnection - Class in org.apache.cassandra.net
-
- IncomingTcpConnection(int, boolean, Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
-
- 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
-
- 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
-
- incrementReadCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Increment the total row read count and read rate for this SSTable.
- incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- 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_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- index_clause - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
-
- index_interval - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- index_interval - Variable in class org.apache.cassandra.thrift.CfDef
-
- index_name - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- index_options - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- index_type - Variable in class org.apache.cassandra.thrift.ColumnDef
-
- IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- indexCfs - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- IndexClause - Class in org.apache.cassandra.thrift
-
Deprecated.
use a KeyRange with row_filter in get_range_slices instead
- 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 - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- indexedEntryEnd() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryNameBuilder - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedEntryStart() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexedKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexEntry - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns true if the provided column name is indexed by this secondary index.
- indexes(ByteBuffer, Set<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- 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.
- indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- indexFor(ByteBuffer, Set<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType<?>, boolean, int) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
The index of the IndexInfo in which a scan starting with @name should begin.
- IndexHelper - Class in org.apache.cassandra.io.sstable
-
Provides helper to serialize, deserialize and use column indexes.
- IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
-
- IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
-
- IndexHelper.IndexInfo(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- indexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- indexName - Variable in class org.apache.cassandra.cql.DropIndexStatement
-
- indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- IndexOperator - Enum in org.apache.cassandra.thrift
-
- IndexPropDefs - Class in org.apache.cassandra.cql3.statements
-
- IndexPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- indexReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- indexRow(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
When building an index against existing data, add the given row to the index
- indexRow(DecoratedKey, ColumnFamilyStore, Set<String>) - Static method in class org.apache.cassandra.db.Keyspace
-
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- IndexSummary - Class in org.apache.cassandra.io.sstable
-
- IndexSummary(IPartitioner, Memory, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
-
- IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
-
- IndexSummary.IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
-
- IndexSummaryBuilder(long, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- 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
-
- inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
-
- init() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- init() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Perform any initialization work
- init(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Initialize the client.
- init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize the Cassandra Daemon based on the given
Commons
Daemon-specific arguments.
- init(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
-
Bind this session to report to specific
StreamResultFuture
and
perform pre-streaming initialization.
- init() - Method in class org.apache.cassandra.utils.MerkleTree
-
Initializes this tree by splitting it until hashdepth is reached,
or until an additional level of splits would violate maxsize.
- initCf(UUID, String, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
adds a cf to internal structures, ends up creating disk files).
- initClient() - Method in class org.apache.cassandra.service.StorageService
-
- initClient(int) - Method in class org.apache.cassandra.service.StorageService
-
- initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- initializeFromMessage(MessageIn<?>) - Method in class org.apache.cassandra.tracing.Tracing
-
Determines the tracing context from a message.
- initializeNodeUnsafe(InetAddress, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
-
- initiate() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up incoming message handler and initiate streaming.
- initiateOnReceivingSide(Socket, boolean, int) - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
Set up outgoing message handler on receiving side.
- initiator - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- initiator - Variable in class org.apache.cassandra.repair.Validator
-
- initLog4j() - Static method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize logging in such a way that it checks for config changes every 10 seconds.
- initReceivingSide(UUID, String, InetAddress, Socket, boolean, int) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
-
- initRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
Methods to get the column family schema from Cassandra
- initServer() - Method in class org.apache.cassandra.service.StorageService
-
- initServer(int) - Method in class org.apache.cassandra.service.StorageService
-
- injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- inOrderDeletionTester() - Method in class org.apache.cassandra.db.ColumnFamily
-
- inOrderTester(boolean) - Method in class org.apache.cassandra.db.DeletionInfo
-
- INotification - Interface in org.apache.cassandra.notifications
-
Created by IntelliJ IDEA.
- INotificationConsumer - Interface in org.apache.cassandra.notifications
-
- inProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- inputVersion - Variable in class org.apache.cassandra.streaming.StreamReader
-
- inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
- insert(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- insert(ByteBuffer, Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
insert a column to the index
- insert(Column) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when constructing the index against pre-existing data
- insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel, 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(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(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- insertUser(String, boolean) - Static method in class org.apache.cassandra.auth.Auth
-
Inserts the user into AUTH_KS.USERS_CF (or overwrites their superuser status as a result of an ALTER USER query).
- instance - Static variable in class org.apache.cassandra.config.Schema
-
- instance - Static variable in class org.apache.cassandra.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.filter.IDiskAtomFilter.Serializer
-
- instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
- instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BooleanType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DateType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LongType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
-
- instance - Static variable in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- instance - Static variable in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- instance - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- instance - Static variable in class org.apache.cassandra.gms.Gossiper
-
- instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
-
- instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
-
- instance - Static 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.BytesSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
-
- instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
-
- instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
-
- instance - Static variable in class org.apache.cassandra.service.CacheService
-
- instance - Static variable in class org.apache.cassandra.service.FileCacheService
-
- instance - Static variable in class org.apache.cassandra.service.GCInspector
-
- instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager
-
- instance - Static variable in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- instance - Static variable in class org.apache.cassandra.service.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 variable in class org.apache.cassandra.utils.HeapAllocator
-
- InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
-
Wraps an ICache in requests + hits tracking.
- InstrumentingCache(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
-
- Int32Serializer - Class in org.apache.cassandra.serializers
-
- Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
-
- Int32Type - Class in org.apache.cassandra.db.marshal
-
- integer(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_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
-
- internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- internedNames - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- internode_authenticator - Variable in class org.apache.cassandra.config.Config
-
- internode_compression - Variable in class org.apache.cassandra.config.Config
-
- internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
- internode_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internode_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- internOrCopy(ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
This method is invoked by any entity wanting to interrogate the status of an endpoint.
- interrupt() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
-
- interruptCompactionFor(Iterable<CFMetaData>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Try to stop all of the compactions for given ColumnFamilies.
- intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
this = this AND other
- intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- intersects(List<ByteBuffer>, List<ByteBuffer>, SliceQueryFilter) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- intersects(List<ByteBuffer>, List<ByteBuffer>, SliceQueryFilter) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
return true if @param range intersects any of the given @param ranges
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
-
- intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
-
- Interval<C,D> - Class in org.apache.cassandra.utils
-
- Interval(C, C, D) - Constructor for class org.apache.cassandra.utils.Interval
-
- intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
-
- intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
-
- IntervalTree<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- IntervalTree(Collection<I>, Comparator<C>) - Constructor for class org.apache.cassandra.utils.IntervalTree
-
- IntervalTree.Serializer<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
call when dropping or renaming a CF.
- invalidate() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Remove the index and unregisters this index's mbean if one exists
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Remove the index
- invalidate(String) - Method in class org.apache.cassandra.service.FileCacheService
-
- invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Invalidates the ranges containing the given token.
- 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
-
- invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- invalidateKeyCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateKeyCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the key cache; for use after invalidating row cache
- invalidateKeyCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- invalidateRowCache() - Method in class org.apache.cassandra.service.CacheService
-
- invalidateRowCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
invalidate the row cache; for use after bulk loading via BinaryMemtable
- invalidateRowCache() - Method in class org.apache.cassandra.tools.NodeProbe
-
- InvalidRequestException - Exception in org.apache.cassandra.exceptions
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
-
- 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.
- invalidSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- inverse() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- inverse() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- IOWAIT_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- IPartitioner<T extends Token> - Interface in org.apache.cassandra.dht
-
- 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_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.
- IRequestSink - Interface in org.apache.cassandra.sink
-
- IResource - Interface in org.apache.cassandra.auth
-
The interface at the core of Cassandra authorization.
- IResponseResolver<TMessage,TResolved> - Interface in org.apache.cassandra.service
-
- IRowCacheEntry - Interface in org.apache.cassandra.cache
-
- IRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- 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
-
- isAlive() - Method in class org.apache.cassandra.gms.EndpointState
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Failure Detector's knowledge of whether a node is up or
down.
- isAlive - Static variable in interface org.apache.cassandra.net.IAsyncCallback
-
- isAlwaysEmpty(AbstractType<?>, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
If IAuthenticator doesn't require authentication, this method may return true.
- ISaslAwareAuthenticator - Interface in org.apache.cassandra.auth
-
- ISaslAwareAuthenticator.SaslAuthenticator - Interface in org.apache.cassandra.auth
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- isAssignableTo(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignementTestable
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
-
- isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAutoCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isAutoCompactionDisabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isAvailable() - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- isAvailable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isBefore(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- isBindMarker() - Method in class org.apache.cassandra.cql.Term
-
- isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
-
- IsBootstrappingException - Exception in org.apache.cassandra.exceptions
-
- IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
-
- isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- isClean() - Method in class org.apache.cassandra.db.Memtable
-
- isCleanerAvailable() - Static method in class org.apache.cassandra.io.util.FileUtils
-
- isClientMode() - Static method in class org.apache.cassandra.config.Config
-
- isClientMode() - Method in class org.apache.cassandra.service.StorageService
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCollection() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- isColumnFamilyLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isColumnList() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
-
- isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- isCompact - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- isCompatibleWith(Operation.RawUpdate) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns true if this comparator is compatible with the provided
previous comparator, that is if previous can safely be replaced by this.
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
-
- isComplete() - Method in interface org.apache.cassandra.auth.ISaslAwareAuthenticator.SaslAuthenticator
-
- isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
-
- isComposite - Variable in class org.apache.cassandra.cql3.CFDefinition
-
- isConnected() - Static method in class org.apache.cassandra.cli.CliMain
-
Checks whether the thrift client is connected.
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCounter() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCounter() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCounter() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isCountOperation() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isCustom - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- 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(Column) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
-
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.DeletionInfo
-
Return whether a given column is deleted by the container having this deletion info.
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.DeletionInfo
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.DeletionTime
-
- isDeleted(Column) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
-
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns whether the given name/timestamp pair is deleted by one of the tombstone
of this RangeTombstoneList.
- 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
-
- isDurable_writes() - Method in class org.apache.cassandra.thrift.KsDef
-
- 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.statements.ColumnGroupMap.Builder
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UserOptions
-
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns true if this contains no columns or deletion info
- isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- isEmpty() - Method in class org.apache.cassandra.db.RowMutation
-
- isEmpty() - Method in class org.apache.cassandra.streaming.StreamPlan
-
- isEmpty() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- isEmpty() - Method in class org.apache.cassandra.utils.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
- isEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
-
- isEncryptedChannel(InetAddress) - Static method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isEQ() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- ISerializer<T> - Interface in org.apache.cassandra.io
-
- isExhausted() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- isExhausted() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Whether or not this pager is exhausted, i.e.
- isExistingUser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the username is stored in AUTH_KS.USERS_CF.
- isExpired() - Method in class org.apache.cassandra.db.Memtable
-
- isFailed() - Method in class org.apache.cassandra.repair.RepairJob
-
- isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
-
- isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isFatClient(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isFullRowSlice(SliceQueryFilter) - Static method in class org.apache.cassandra.db.DataRange
-
- isFullWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- isGcAble(int) - Method in class org.apache.cassandra.db.DeletionTime
-
- isGlobal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isIN() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isIncrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.service.StorageService
-
- isIncrementalBackupsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
true if this CFS contains secondary index data
- isIndexBuilt(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Checks if the index for specified column is fully built
- isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- isIndexed() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- isIndexEntryStale(ByteBuffer, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- isIndexing(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- isIndexNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isInitialized() - Method in class org.apache.cassandra.service.StorageService
-
- isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns if this map only support inserts in reverse order.
- isInsertReversed() - Method in class org.apache.cassandra.db.EmptyColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- isInsertReversed() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- isInShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
- isJoined() - Method in class org.apache.cassandra.service.StorageService
-
- isJoined() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isJoined() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
-
- isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.net.AsyncOneResponse
-
- isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IAsyncCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isListening() - Method in class org.apache.cassandra.net.MessagingService
-
- isLive(long) - Method in class org.apache.cassandra.db.Column
-
- isLive() - Method in class org.apache.cassandra.db.DeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- isLive(Column, DeletionInfo.InOrderTester, long) - Static method in class org.apache.cassandra.db.filter.ColumnCounter
-
- isLocal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isLocalId() - Method in class org.apache.cassandra.utils.CounterId
-
- isLocalTask() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
Returns true if the task if the task can be executed locally, false if
it has to be forwarded.
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.Column
-
- isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
-
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.DeletedColumn
-
- isMarkedForDelete(long) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in class org.apache.cassandra.db.RowPosition
-
- isMinimum(IPartitioner) - Method in interface org.apache.cassandra.dht.RingPosition
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- isMinimum() - Method in class org.apache.cassandra.dht.Token
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- isMinimumBound - Variable in class org.apache.cassandra.dht.Token.KeyBound
-
- isModified() - Method in class org.apache.cassandra.utils.DefaultDouble
-
- isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMultiKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isMultiKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- isMultithreadedCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- iso8601Patterns - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
-
- 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_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_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 class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isOnToken() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Checks whether the socket is connected.
- isOutgoingConnected() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- isPaging - Variable in class org.apache.cassandra.db.RangeSliceCommand
-
- isPartOfCellName() - Method in class org.apache.cassandra.config.ColumnDefinition
-
Whether the name of this definition is serialized in the cell nane, i.e.
- isPartOfTuple() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- 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
-
- isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
-
- isPresent(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
-
- isPrimaryKeyColumn() - Method in class org.apache.cassandra.cql3.CFDefinition.Name
-
- isPure() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- isPure() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
-
- isRelocating(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isReplicate_on_write() - Method in class org.apache.cassandra.thrift.CfDef
-
- 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.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.SliceRange
-
- isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Returns whether the server is currently running.
- isRunning() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- isRunning() - Method in class org.apache.cassandra.transport.Server
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, ColumnNameBuilder) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- isSatisfiedBy(DecoratedKey, ColumnFamily, ColumnNameBuilder) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
-
- isSequential - Variable in class org.apache.cassandra.repair.RepairSession
-
- isSerialConsistency() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- 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_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(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(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
- 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
- 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_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_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
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
True if an explicit consistency level was parsed from the statement.
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
True if an explicit consistency level was parsed from the statement.
- 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.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.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_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_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.cql.SelectStatement
-
- 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
- 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
- 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
- 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.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_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_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.cql.AbstractModification
-
- isSetTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
-
- 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_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
- 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.db.commitlog.AbstractCommitLogExecutorService
-
- isSignaled() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.IN
-
- isSlice() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- ISSTableSerializer<T> - Interface in org.apache.cassandra.io
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
-
- isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
-
- isStatic(CFMetaData) - Method in class org.apache.cassandra.cql3.Operation
-
- isStatic - Variable in class org.apache.cassandra.cql3.statements.ColumnGroupMap
-
- isStatic(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isStaticName(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isSuccess() - Method in class org.apache.cassandra.streaming.StreamSession
-
Return if this session completed successfully.
- isSuccess() - Method in class org.apache.cassandra.thrift.CASResult
-
- isSuccessful() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- isSufficientLiveNodes(Keyspace, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Checks the user's superuser status.
- isSuper() - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperuser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the user is a known superuser.
- isSupportedBy(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- isThriftCompatible() - Method in class org.apache.cassandra.config.CFMetaData
-
Returns whether this CFMetaData can be returned to thrift.
- isThriftCompatible() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTimestampSet() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- isTimeToLiveSet() - Method in class org.apache.cassandra.cql3.Attributes
-
- isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
-
Indicates if the current thread's execution is being traced.
- isTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- isUnary() - Method in class org.apache.cassandra.cql.Operation
-
- isUnix() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- isUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for reads.
- isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for writes.
- isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Returns true if values of the previous AbstracType can be read by the this
AbsractType.
- isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
-
- isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- isVersion2x() - Static method in class org.apache.cassandra.hadoop.HadoopCompat
-
True if runtime Hadoop version is 2.x, false otherwise.
- isWildcard() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isWildcard() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
Returns whether for a range query doing a query against merged is likely
to be faster than 2 sequential queries, one against l1 followed by one against l2.
- isWrapAround() - Method in class org.apache.cassandra.db.DataRange
-
- isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
-
Tells if the given range is a wrap around.
- isWrapAround() - Method in class org.apache.cassandra.dht.Range
-
- isWritetime - Variable in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- 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() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- iterator() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- iterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns an iterator over the columns of this map that returns only the matching @param slices.
- iterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- iterator() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
-
- iterator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
-
- iterator() - Method in class org.apache.cassandra.db.compaction.ParallelCompactionIterable
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.EmptyColumns
-
- iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- iterator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- iterator() - Method in class org.apache.cassandra.db.UnsortedColumns
-
- iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- iterator - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- iterator(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- iterator() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- iterator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
-
- iterators() - Method in interface org.apache.cassandra.utils.IMergeIterator
-
- iterators - Variable in class org.apache.cassandra.utils.MergeIterator
-
- iterators() - Method in class org.apache.cassandra.utils.MergeIterator
-
- ITransportFactory - Interface in org.apache.cassandra.thrift
-
Transport factory for establishing thrift connections from clients to a remote server.
- ITrigger - Interface in org.apache.cassandra.triggers
-
- IVerbHandler<T> - Interface in org.apache.cassandra.net
-
IVerbHandler provides the method that all verb handlers need to implement.
- IVersionedSerializer<T> - Interface in org.apache.cassandra.io
-
- r1 - Variable in class org.apache.cassandra.repair.Differencer
-
- r2 - Variable in class org.apache.cassandra.repair.Differencer
-
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rack - Variable in class org.apache.cassandra.thrift.EndpointDetails
-
- rack_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Rack
-
- RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
-
- RackInferringSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded
in the 2nd and 3rd octets of the ip address, respectively.
- RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
-
- racks - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- RandomAccessReader - Class in org.apache.cassandra.io.util
-
- RandomAccessReader(File, int, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
-
- RandomAccessReader.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
-
Class to hold a mark to the position of the file
- RandomAccessReader.BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader.BufferedRandomAccessFileMark
-
- RandomPartitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using MD5 hash.
- RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
-
- Range<T extends RingPosition> - Class in org.apache.cassandra.dht
-
A representation of the range that a node is responsible for on the DHT ring.
- Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
-
- Range(T, T, IPartitioner) - Constructor for class org.apache.cassandra.dht.Range
-
- range - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
repairing range
- range - Variable in class org.apache.cassandra.repair.RepairSession
-
Range to repair
- range - 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_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RANGE_TOMBSTONE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
-
- RANGE_XFERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- rangeCount() - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeCovering(ByteBuffer) - Method in class org.apache.cassandra.db.DeletionInfo
-
- rangeIterator() - Method in class org.apache.cassandra.db.DeletionInfo
-
- RangeNamesQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a name query.
- ranges - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
-
- RangeSliceCommand - Class in org.apache.cassandra.db
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
-
- RangeSliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pages a RangeSliceCommand whose predicate is a slice query.
- RangeSliceReply - Class in org.apache.cassandra.db
-
- RangeSliceReply(List<Row>) - Constructor for class org.apache.cassandra.db.RangeSliceReply
-
- RangeSliceResponseResolver - Class in org.apache.cassandra.service
-
Turns RangeSliceReply objects into row (string -> CF) maps, resolving
to the most recent ColumnFamily and setting up read repairs as necessary.
- RangeSliceResponseResolver(String, long) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
-
- RangeSliceVerbHandler - Class in org.apache.cassandra.service
-
- RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
-
- RangeStreamer - Class in org.apache.cassandra.dht
-
Assists in streaming ranges to a node.
- RangeStreamer(TokenMetadata, InetAddress, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer
-
- RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not alive according to a
failure detector.
- RangeStreamer.FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- RangeStreamer.ISourceFilter - Interface in org.apache.cassandra.dht
-
A filter applied to sources to stream from when constructing a fetch map.
- RangeStreamer.SingleDatacenterFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes any endpoints that are not in a specific data center.
- RangeStreamer.SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- RangeTombstone - Class in org.apache.cassandra.db
-
- RangeTombstone(ByteBuffer, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone(ByteBuffer, ByteBuffer, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
-
- RangeTombstone.Serializer - Class in org.apache.cassandra.db
-
- RangeTombstone.Serializer() - Constructor for class org.apache.cassandra.db.RangeTombstone.Serializer
-
- RangeTombstone.Tracker - Class in org.apache.cassandra.db
-
- RangeTombstone.Tracker(Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.RangeTombstone.Tracker
-
- RangeTombstoneList - Class in org.apache.cassandra.db
-
Data structure holding the range tombstones of a ColumnFamily.
- RangeTombstoneList(Comparator<ByteBuffer>, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
-
- RangeTombstoneList.InOrderTester - Class in org.apache.cassandra.db
-
This object allow testing whether a given column (name/timestamp) is deleted
or not by this RangeTombstoneList, assuming that the column given to this
object are passed in (comparator) sorted order.
- RangeTombstoneList.InOrderTester() - Constructor for class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
-
- RangeTombstoneList.Serializer - Class in org.apache.cassandra.db
-
- RangeXfersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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.
- rawAppend(ColumnFamily, long, DecoratedKey, DataOutput) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- RawSelector - Class in org.apache.cassandra.cql3.statements
-
- RawSelector(Selectable, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.statements.RawSelector
-
- read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
-
- read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- read() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads a single byte from the source byte array and returns it as an
integer in the range from 0 to 255.
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads at most len
bytes from this stream and stores
them in byte array b
starting at offset
.
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(DataInput, int, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
- read() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
-
- read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.StreamReader
-
- read(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_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.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.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
-
- readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a boolean from the current position in this file.
- readBoolean() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an 8-bit byte from the current position in this file.
- readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readBytes(int) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
Read length bytes from current file position
- readBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
Does the same thing as readFully
do but without copying data (thread safe)
- readBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- readBytes(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadCallback<TMessage,TResolved> - Class in org.apache.cassandra.service
-
- ReadCallback(IResponseResolver<TMessage, TResolved>, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
-
Constructor when response count has to be calculated and blocked for.
- 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.utils.BytesReadTracker
-
- readColumnFamily(List<ReadCommand>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- ReadCommand - Class in org.apache.cassandra.db
-
- ReadCommand(String, ByteBuffer, String, long, ReadCommand.Type) - Constructor for class org.apache.cassandra.db.ReadCommand
-
- ReadCommand.Type - Enum in org.apache.cassandra.db
-
- readConsistencyLevel(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readDouble() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit double from the current position in this file.
- readDouble() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readEnumValue(Class<T>, ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- readFilter() - Method in class org.apache.cassandra.cql3.statements.CQL3CasConditions
-
- readFilter() - Method in interface org.apache.cassandra.service.CASConditions
-
The filter to use to fetch the value to compare for the CAS.
- readFloat() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit float from the current position in this file.
- readFloat() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads bytes from this file into buffer
.
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Read bytes from this file into buffer
starting at offset offset
.
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInet(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 32-bit integer from the current position in this file.
- readInt() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInt() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- 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
- readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a line of text form the current position in this file.
- readLine() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit long from the current position in this file.
- readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readLongString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readMeter - Variable in class org.apache.cassandra.io.sstable.SSTableReader
-
- readNextChar() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- readRawBytes(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- ReadRepairDecision - Enum in org.apache.cassandra.config
-
- ReadRepairMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Read Repair.
- ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
-
- ReadRepairVerbHandler - Class in org.apache.cassandra.db
-
- ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
-
- readRequiredRows(Collection<ByteBuffer>, ColumnNameBuilder, boolean, ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- ReadResponse - Class in org.apache.cassandra.db
-
- ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
-
- readSchemaRow(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- readSchemaRow(String, String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Fetches a subset of schema (table data, columns metadata or triggers) for the keyspace+table pair.
- readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 16-bit short from the current position in this file.
- readShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringList(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readStringToStringListMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadTimeoutException - Exception in org.apache.cassandra.exceptions
-
- ReadTimeoutException(ConsistencyLevel, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadTimeoutException
-
- readTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Reads the list of components from the TOC component.
- readUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 8-bit byte from the current position in this file and
returns it as an integer.
- readUnsignedByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 16-bit short from the current position in this file and
returns it as an integer.
- readUnsignedShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a string that is encoded in modified UTF-8
from
this file.
- readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUUID(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readValue(ChannelBuffer) - Method in enum org.apache.cassandra.transport.DataType
-
- readValue(ChannelBuffer) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- readValueList(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- ReadVerbHandler - Class in org.apache.cassandra.db
-
- ReadVerbHandler() - Constructor for class org.apache.cassandra.db.ReadVerbHandler
-
- readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- ReadyMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- ReadyMessage() - Constructor for class org.apache.cassandra.transport.messages.ReadyMessage
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
Read data from file starting from current currentOffset to populate buffer.
- reBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- reBuffer() - Method in class org.apache.cassandra.io.util.ThrottledReader
-
- rebuild() - Method in class org.apache.cassandra.config.CFMetaData
-
- rebuild(String) - Method in class org.apache.cassandra.service.StorageService
-
- rebuild(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Initiate a process of streaming data for which we are responsible from other nodes.
- rebuild(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- rebuildSecondaryIndex(String, String, String...) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- rebuildSecondaryIndex(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- rebuildSecondaryIndex(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
rebuild the specified indexes
- receive(MessageIn, int, long) - Method in class org.apache.cassandra.net.MessagingService
-
- receive(IncomingFileMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after receiving FileMessageHeader.
- received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
-
- received(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
-
- receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
-
- receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Immutable collection of receiving summaries
- recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Number of false positives in bloom filter from last read
- recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
False positive ratio of bloom filter from last read
- recentLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- recentSSTablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- recognizedOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- recognizedOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- reconcile(Column) - Method in class org.apache.cassandra.db.Column
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.Column
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.CounterColumn
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- reconcile(Column, Allocator) - Method in class org.apache.cassandra.db.DeletedColumn
-
- ReconnectableSnitchHelper - Class in org.apache.cassandra.locator
-
Sidekick helper for snitches that want to reconnect from one IP addr for a node to another.
- ReconnectableSnitchHelper(IEndpointSnitch, String, boolean) - Constructor for class org.apache.cassandra.locator.ReconnectableSnitchHelper
-
- recordColumnDrop(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- recordLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- recover() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on commit logs located in the directory specified by the config file.
- recover(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a list of commit log files.
- recover(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Perform recovery on a single commit log.
- recover(String) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Recover a single file.
- recover(File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- recover(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- 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_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() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Recycle processes an unneeded segment file for reuse.
- recycle(RandomAccessReader) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
-
- recycleSegment(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Indicates that a segment is no longer in use and that it should be recycled.
- recycleSegment(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Differs from the above because it can work on any file instead of just existing
commit log segments managed by this allocator.
- reduce(OnDiskAtomIterator) - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- reduce(In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
combine this object with the previous ones.
- reducer - Variable in class org.apache.cassandra.utils.MergeIterator
-
- reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Called if no disk is available with free space for the full write size.
- ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
-
Caller must acquire and release references to the sstables used here.
- ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- RefCountedMemory - Class in org.apache.cassandra.cache
-
- RefCountedMemory(long) - Constructor for class org.apache.cassandra.cache.RefCountedMemory
-
- reference() - Method in class org.apache.cassandra.cache.RefCountedMemory
-
- refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
-
- register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
-
Register for interesting state changes.
- register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
-
- register(IMigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
-
- register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
-
- register(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
-
- registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Register interest for Failure Detector events.
- RegisterMessage - Class in org.apache.cassandra.transport.messages
-
- RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
-
- registerReceiving(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
-
- registerVerbHandlers(MessagingService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
-
Register a verb and the corresponding verb handler with the
Messaging Service.
- regularAndStaticColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- regularAndStaticColumnsToFetch() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- regularColumns() - Method in class org.apache.cassandra.config.CFMetaData
-
- regularColumns() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- regularDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- Relation - Class in org.apache.cassandra.cql
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- Relation(Term, String, Term) - Constructor for class org.apache.cassandra.cql.Relation
-
Creates a new relation.
- Relation - Class in org.apache.cassandra.cql3
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- Relation(ColumnIdentifier, Relation.Type, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Relation
-
Creates a new relation.
- Relation(ColumnIdentifier, Relation.Type, Term.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.Relation
-
- Relation(ColumnIdentifier, Relation.Type, Term.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.Relation
-
- Relation.Type - Enum in org.apache.cassandra.cql3
-
- relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Release all associated metrics.
- release() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
- release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
- release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
- release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
-
A convenience method for indicating when a particular request has completed
processing, and before a return to the client
- release() - Method in class org.apache.cassandra.scheduler.NoScheduler
-
- release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- releaseReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Release reference to this SSTableReader.
- releaseReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- releaseSummary() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- reload() - Method in class org.apache.cassandra.config.CFMetaData
-
- reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- reload() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Reload an existing index following a change to its configuration,
or that of the indexed column(s).
- reload() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Drops and adds new indexes associated with the underlying CF
- reloadAttributes() - Method in class org.apache.cassandra.config.KSMetaData
-
- reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
-
Reload the triggers which is already loaded, Invoking this will update
the class loader so new jars can be loaded.
- reloadConfiguration() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
-
- reloadSecondaryIndexMetadata(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Reloads the sstable metadata from disk.
- 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
-
- relocate(Collection<String>) - Method in class org.apache.cassandra.service.StorageService
-
- relocate(Collection<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- relocating(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- remaining - Variable in class org.apache.cassandra.service.pager.PagingState
-
- remainingCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- remove(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- remove(K) - Method in interface org.apache.cassandra.cache.ICache
-
- remove(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- remove(K) - Method in class org.apache.cassandra.cache.SerializingCache
-
- remove() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- remove(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- remove(Column) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
-
called when lazy-updating the index during compaction (CASSANDRA-2897)
- remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
remove endpoint from failure detector
- remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- remove(IMessageSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- remove(IRequestSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- 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(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(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.ConcurrentBiMap
-
- remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
-
- 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(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(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- removed - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes deleted columns and purges gc-able tombstones.
- removeDeleted(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removeDeleted(DecoratedKey, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- removeDeleted(DecoratedKey, boolean, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
-
- removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
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).
- removeDeletedColumnsOnly(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- removedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
-
- removedNonlocal(UUID, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- removeEndpoint(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Remove stored tokens being used by another node
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Removes the endpoint from Gossip but retains endpoint state
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
Removes current DC/rack assignment for ep
- removeFromActiveSessions(RepairSession) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from moving endpoints
- removeFromRelocating(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from relocating ranges.
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Delete all files and references to this index
- removeIndexedColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Removes a existing index
- removeKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace from schema
- removeNode(String) - Method in class org.apache.cassandra.service.StorageService
-
Remove a node that has died, attempting to restore the replica count.
- removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
removeToken removes token (and all data associated with
enpoint that had it) from the ring
- removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
-
- removePostPreparationHook(PostPreparationHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- removePreExecutionHook(PreExecutionHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- removeRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- removeTrigger(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
This method is used to remove information about truncation time for specified column family
- removeUnfinishedCompactionLeftovers(String, String, Map<Integer, UUID>) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Replacing compacted sstables is atomic as far as observers of DataTracker are concerned, but not on the
filesystem: first the new sstables are renamed to "live" status (i.e., the tmp marker is removed), then
their ancestors are removed.
- removeUnreadableSSTables(File) - Static method in class org.apache.cassandra.db.Keyspace
-
Removes every SSTable in the directory from the appropriate DataTracker's view.
- removeValue(V) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removingNonlocal(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rename(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- renameColumn(ByteBuffer, String, ByteBuffer, String) - Method in class org.apache.cassandra.config.CFMetaData
-
- renameWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
-
- renewLocalId() - Static method in class org.apache.cassandra.utils.CounterId
-
Renew the local counter id.
- renewLocalId(long) - Static method in class org.apache.cassandra.utils.CounterId
-
- renewMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
Renew the current memtable without putting the old one for a flush.
- repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- RepairException - Exception in org.apache.cassandra.exceptions
-
Exception thrown during repair
- RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairException(RepairJobDesc, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RepairException
-
- RepairFuture - Class in org.apache.cassandra.repair
-
- RepairFuture(RepairSession) - Constructor for class org.apache.cassandra.repair.RepairFuture
-
- RepairJob - Class in org.apache.cassandra.repair
-
RepairJob runs repair on given ColumnFamily.
- RepairJob(UUID, String, String, Range<Token>, boolean, 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, String, String, Range<Token>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
-
- RepairMessage - Class in org.apache.cassandra.repair.messages
-
Base class of all repair related request/response messages.
- RepairMessage(RepairMessage.Type, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
-
- RepairMessage.MessageSerializer<T extends RepairMessage> - Interface in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer - Class in org.apache.cassandra.repair.messages
-
- RepairMessage.RepairMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- RepairMessage.Type - Enum in org.apache.cassandra.repair.messages
-
- RepairMessageVerbHandler - Class in org.apache.cassandra.repair
-
Handles all repair related message.
- RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
-
- repairOverlappingSSTables(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- repairResults - Variable in class org.apache.cassandra.service.RowDataResolver
-
- RepairSession - Class in org.apache.cassandra.repair
-
Coordinates the (active) repair of a token range.
- RepairSession(Range<Token>, String, boolean, Collection<String>, Collection<String>, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
-
Create new repair session.
- RepairSession(UUID, Range<Token>, String, boolean, Collection<String>, Collection<String>, String[]) - Constructor for class org.apache.cassandra.repair.RepairSession
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- replace(K, V, V) - Method in interface org.apache.cassandra.cache.ICache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- replace(K, V, V) - Method in class org.apache.cassandra.cache.SerializingCache
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.ColumnFamily
-
Replace oldColumn if present by newColumn.
- replace(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.EmptyColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- replace(Column, Column) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
-
- replacedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
- replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Handle a flushed memtable.
- replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
-
- ReplayPosition - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- replayPosition(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition.ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- replicasMissingMostRecentCommit() - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- replicate_on_write - Variable in class org.apache.cassandra.thrift.CfDef
-
- replicateOnWrite(boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- reportSeverity(double) - Method in class org.apache.cassandra.service.StorageService
-
Increment about the known Compaction severity of the events in this node
- representJavaBeanProperty(Object, Property, Object, Tag) - Method in class org.apache.cassandra.utils.SkipNullRepresenter
-
- request - Variable in class org.apache.cassandra.repair.StreamingRepairTask
-
- request_scheduler - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_id - Variable in class org.apache.cassandra.config.Config
-
- request_scheduler_options - Variable in class org.apache.cassandra.config.Config
-
- request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- RequestCoordinator<R> - Class in org.apache.cassandra.repair
-
- RequestCoordinator(boolean) - Constructor for class org.apache.cassandra.repair.RequestCoordinator
-
- RequestExecutionException - Exception in org.apache.cassandra.exceptions
-
- RequestExecutionException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- RequestExecutionException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
-
- requestGC() - Method in class org.apache.cassandra.service.StorageService
-
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- requestRanges(InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in keyspace
and ranges
from specific node.
- requestRanges(InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in columnFamilies
under keyspace
and ranges
from specific node.
- requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total number of cache requests
- requests - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
-
Total number of requests
- requests - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Streaming requests
- RequestSchedulerOptions - Class in org.apache.cassandra.config
-
- RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
-
- RequestThreadPoolExecutor - Class in org.apache.cassandra.transport
-
- RequestThreadPoolExecutor() - Constructor for class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- RequestTimeoutException - Exception in org.apache.cassandra.exceptions
-
- RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- RequestType - Enum in org.apache.cassandra.thrift
-
- RequestValidationException - Exception in org.apache.cassandra.exceptions
-
- RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
-
- require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Whether or not the authenticator requires explicit login.
- requireAuthentication() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
-
- REQUIRES_KEYSPACE - Static variable in enum org.apache.cassandra.cql.StatementType
-
Statement types that require a keyspace to be set
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
-
- requiresRead() - Method in class org.apache.cassandra.cql3.Operation
-
- rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
-
- rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
Retry all deletions that failed the first time around (presumably b/c the sstable was still mmap'd.)
Useful because there are times when we know GC has been invoked; also exposed as an mbean.
- reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Resets this stream to the last marked location.
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Resets this stream to the beginning of the underlying byte array.
- reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
reconnect to @param remoteEP (after the current message backlog is exhausted).
- reset(long) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
reset counter to @param count
- reset() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- reset() - Method in class org.apache.cassandra.utils.ExpiringMap
-
- reset() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- reset() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
Reset the writer so that the next chunk offset written will be the
one of chunkIndex
.
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetChecksum() - Method in class org.apache.cassandra.io.util.ChecksummedOutputStream
-
- resetEndpointStateMap() - Method in class org.apache.cassandra.gms.Gossiper
-
- resetLocalSchema() - Static method in class org.apache.cassandra.service.MigrationManager
-
Clear all locally stored schema information and reset schema to initial state.
- resetLocalSchema() - Method in class org.apache.cassandra.service.StorageService
-
- resetLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- resetLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
-
- resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Resets all the segments, for testing purposes.
- resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- resolve(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
-
- resolve(ColumnFamily, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
-
- resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
-
This Method resolves the responses that are passed in .
- resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDataResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
-
- resolver - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- resolver - Variable in class org.apache.cassandra.service.ReadCallback
-
- resource - Variable in class org.apache.cassandra.auth.PermissionDetails
-
- resource - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- Resources - Class in org.apache.cassandra.auth
-
- Resources() - Constructor for class org.apache.cassandra.auth.Resources
-
- resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ResourceWatcher - Class in org.apache.cassandra.utils
-
- ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
-
- ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
-
- ResourceWatcher.WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- 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.service.AbstractWriteResponseHandler
-
null message means "response from local write"
- response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AsyncRepairCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
-
- response(MessageIn<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- response(MessageIn<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
-
- response(MessageIn<TMessage>) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(TMessage) - Method in class org.apache.cassandra.service.ReadCallback
-
- response(MessageIn) - Method in class org.apache.cassandra.service.TruncateResponseHandler
-
- response(MessageIn) - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- responseCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
-
- responsePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
-
- ResponseVerbHandler - Class in org.apache.cassandra.net
-
- ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
-
- 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.statements
-
A restriction/clause on a column.
- Restriction.EQ - Class in org.apache.cassandra.cql3.statements
-
- Restriction.EQ(Term, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- Restriction.IN - Class in org.apache.cassandra.cql3.statements
-
- Restriction.IN() - Constructor for class org.apache.cassandra.cql3.statements.Restriction.IN
-
- Restriction.Slice - Class in org.apache.cassandra.cql3.statements
-
- Restriction.Slice(boolean) - Constructor for class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- ResultMessage - Class in org.apache.cassandra.transport.messages
-
- ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
-
- ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Prepared(MD5Digest, ParsedStatement.Prepared) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- ResultMessage.SchemaChange.Change - Enum in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- ResultMessage.Void - Class in org.apache.cassandra.transport.messages
-
- ResultMessage.Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- ResultSet - Class in org.apache.cassandra.cql3
-
- ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet(ResultSet.Metadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
-
- ResultSet.Codec - Class in org.apache.cassandra.cql3
-
- ResultSet.Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
-
- ResultSet.Flag - Enum in org.apache.cassandra.cql3
-
- ResultSet.Metadata - Class in org.apache.cassandra.cql3
-
- ResultSet.Metadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.Metadata
-
- resultSetBuilder(long) - Method in class org.apache.cassandra.cql3.statements.Selection
-
- resume() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
For internal, temporary suspension of background compactions so that we can do exceptional
things like truncate or major compaction
- resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
-
- rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
-
- RetriedSliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
-
- retry(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.RETRY
message.
- RetryMessage - Class in org.apache.cassandra.streaming.messages
-
- RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
-
- returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- reverse() - Method in class org.apache.cassandra.cql3.ResultSet
-
- reverse(Bound) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
- reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
-
- reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- 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.AtomicSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
-
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
- reverseIterator() - Method in class org.apache.cassandra.db.ColumnFamily
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.EmptyColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
-
- reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.UnsortedColumns
-
- reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
-
- reverseMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
-
- revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Revokes a set of permissions on a resource from a user.
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called before deleting a user with DROP USER query so that a new user with the same
name wouldn't inherit permissions of the deleted user in the future.
- revokeAll(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called after a resource is removed (i.e.
- revokeAll(String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- RevokeStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokeStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.RevokeStatement
-
- right - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- right - Variable in class org.apache.cassandra.utils.Pair
-
- RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
-
- RingCache - Class in org.apache.cassandra.client
-
A class for caching the ring map at the client.
- RingCache(Configuration) - Constructor for class org.apache.cassandra.client.RingCache
-
- ringCache - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
iterator over the Tokens in the given ring, starting with the token for the node owning start
(which does not have to be a Token in the ring)
- RingPosition<T> - Interface in org.apache.cassandra.dht
-
Interface representing a position on the ring.
- root() - Static method in class org.apache.cassandra.auth.DataResource
-
- ROOT - Static variable in class org.apache.cassandra.auth.Resources
-
Deprecated.
- rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
-
- RoundRobinScheduler - Class in org.apache.cassandra.scheduler
-
A very basic Round Robin implementation of the RequestScheduler.
- RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
-
- roundTo(long, int) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
- row() - Method in class org.apache.cassandra.db.ReadResponse
-
- Row - Class in org.apache.cassandra.db
-
- Row(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
-
- Row.RowSerializer - Class in org.apache.cassandra.db
-
- Row.RowSerializer() - Constructor for class org.apache.cassandra.db.Row.RowSerializer
-
- row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
-
- row_cache_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.service.CacheService
-
- RowCacheKey - Class in org.apache.cassandra.cache
-
- RowCacheKey(UUID, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheKey(UUID, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
-
- RowCacheSentinel - Class in org.apache.cassandra.cache
-
A sentinel object for row caches.
- RowCacheSentinel() - Constructor for class org.apache.cassandra.cache.RowCacheSentinel
-
- RowDataResolver - Class in org.apache.cassandra.service
-
- RowDataResolver(String, ByteBuffer, IDiskAtomFilter, long) - Constructor for class org.apache.cassandra.service.RowDataResolver
-
- RowDigestResolver - Class in org.apache.cassandra.service
-
- RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
-
- rowFilter - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- RowIndexEntry - Class in org.apache.cassandra.db
-
- RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
-
- RowIndexEntry.Serializer - Class in org.apache.cassandra.db
-
- RowIndexEntry.Serializer() - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- RowIteratorFactory - Class in org.apache.cassandra.db
-
- RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
-
- rowMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- RowMutation - Class in org.apache.cassandra.db
-
- RowMutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(String, ByteBuffer, Map<UUID, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.RowMutation
-
- RowMutation.RowMutationSerializer - Class in org.apache.cassandra.db
-
- RowMutation.RowMutationSerializer() - Constructor for class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- RowMutationVerbHandler - Class in org.apache.cassandra.db
-
- RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
-
- RowPosition - Class in org.apache.cassandra.db
-
- RowPosition() - Constructor for class org.apache.cassandra.db.RowPosition
-
- RowPosition.Kind - Enum in org.apache.cassandra.db
-
- RowPosition.RowPositionSerializer - Class in org.apache.cassandra.db
-
- RowPosition.RowPositionSerializer() - Constructor for class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- rows - Variable in class org.apache.cassandra.cql3.ResultSet
-
- rows - Variable in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- rows - Variable in class org.apache.cassandra.db.RangeSliceReply
-
- rows - Variable in class org.apache.cassandra.thrift.CqlResult
-
- rowsOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rowsOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- rpc_address - Variable in class org.apache.cassandra.config.Config
-
- rpc_endpoints - Variable in class org.apache.cassandra.thrift.TokenRange
-
- rpc_keepalive - Variable in class org.apache.cassandra.config.Config
-
- rpc_max_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_min_threads - Variable in class org.apache.cassandra.config.Config
-
- rpc_port - Variable in class org.apache.cassandra.config.Config
-
- rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
-
- rpc_server_type - Variable in class org.apache.cassandra.config.Config
-
- rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rpcPort - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- run() - Method in class org.apache.cassandra.db.MeteredFlusher
-
- run - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- run() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
Loops collecting mutations from the queue and sending to Cassandra
- run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- run() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
-
- run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
-
A new connection will either stream or message for its entire lifetime: because streaming
bypasses the InputStream implementations to use sendFile, we cannot begin buffering until
we've determined the type of the connection.
- run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
-
- run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
-
- run() - Method in class org.apache.cassandra.repair.Differencer
-
Compares our trees, and triggers repairs for any ranges that mismatch.
- run() - Method in class org.apache.cassandra.repair.SnapshotTask
-
- run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
-
- run() - Method in class org.apache.cassandra.repair.Validator
-
Called after the validation lifecycle to respond with the now valid tree.
- run() - Method in class org.apache.cassandra.transport.Client
-
- run() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor.BackgroundActivityReporter
-
- run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
-
- run() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runMayThrow() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Run this task after selecting the optimal disk for it
- runMayThrow() - Method in class org.apache.cassandra.repair.RepairSession
-
- runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runWith(File) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
For internal use and testing only.
- runWith(File) - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Executes this task on given sstableDirectory
.
- runWithCompactionsDisabled(Callable<V>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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
-
- satisfies(int, IndexOperator) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
-
- saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
-
- saveCaches() - Method in class org.apache.cassandra.service.CacheService
-
- saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
save row and key caches
- saved_caches_directory - Variable in class org.apache.cassandra.config.Config
-
- savePaxosCommit(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosPromise(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- saveSummary(SSTableReader, SegmentedFile.Builder, SegmentedFile.Builder) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- schedule() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- ScheduledRangeTransferExecutorService - Class in org.apache.cassandra.service
-
- ScheduledRangeTransferExecutorService() - Constructor for class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
-
- scheduledTasks - Static variable in class org.apache.cassandra.service.StorageService
-
This pool is used for periodic short (sub-second) tasks.
- scheduleHintDelivery(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- scheduleHintDelivery(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
force hint delivery to an endpoint
- scheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowDataResolver
-
For each row version, compare with resolved (the superset of all row versions);
if it is missing anything, send a mutation to the endpoint it come from.
- scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- 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
- schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- schema - Variable in class org.apache.cassandra.thrift.CqlResult
-
- SCHEMA_COLUMNFAMILIES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_COLUMNS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_KEYSPACES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_TRIGGERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SchemaAlteringStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that alter the schema.
- SchemaAlteringStatement() - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- SchemaAlteringStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- schemaCFS(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- SchemaCheckVerbHandler - Class in org.apache.cassandra.db
-
- SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
-
- SchemaColumnFamiliesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaColumnsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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.
- SchemaKeyspacesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaTriggersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- scName - Variable in class org.apache.cassandra.db.SuperColumns.SCFilter
-
- scName(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- scrub(boolean, boolean) - 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, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace.
- scrub(boolean, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Scrubber - Class in org.apache.cassandra.db.compaction
-
- Scrubber(ColumnFamilyStore, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, SSTableReader, boolean, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- scrubDataDirectories(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
and compacted sstables.
- 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
TODO: add support for querying across index types
- search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- search(ByteBuffer) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Returns the DeletionTime for the tombstone overlapping name
(there can't be more than one),
or null if name
is not covered by any tombstone.
- search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
-
- search(C) - Method in class org.apache.cassandra.utils.IntervalTree
-
- searchComposite(String, boolean) - Static method in class org.apache.cassandra.db.DefsTables
-
- SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
-
- SecondaryIndex - Class in org.apache.cassandra.db.index
-
Abstract base class for different types of secondary indexes.
- SecondaryIndex() - Constructor for class org.apache.cassandra.db.index.SecondaryIndex
-
- SecondaryIndexBuilder - Class in org.apache.cassandra.db.index
-
Manages building an entire index from column family data.
- SecondaryIndexBuilder(ColumnFamilyStore, Set<String>, ReducingKeyIterator) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexBuilder
-
- SecondaryIndexManager - Class in org.apache.cassandra.db.index
-
Manages all the indexes associated with a given CFS
Different types of indexes can be created across the same CF
- SecondaryIndexManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexManager
-
- SecondaryIndexManager.Updater - Interface in org.apache.cassandra.db.index
-
- SecondaryIndexSearcher - Class in org.apache.cassandra.db.index
-
- SecondaryIndexSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- sections - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamReader
-
- sections - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sections - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- seed_provider - Variable in class org.apache.cassandra.config.Config
-
- SeedProvider - Interface in org.apache.cassandra.locator
-
- SeedProviderDef - Class in org.apache.cassandra.config
-
- SeedProviderDef(LinkedHashMap<String, ?>) - Constructor for class org.apache.cassandra.config.SeedProviderDef
-
- seek(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- seek(long) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- seekInternal(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
-
- segment - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- SegmentedFile - Class in org.apache.cassandra.io.util
-
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent
FileDataInput.
- SegmentedFile(String, long, long) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
-
- SegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
Collects potential segmentation points in an underlying file, and builds a SegmentedFile to represent it.
- SegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- selectable - Variable in class org.apache.cassandra.cql3.statements.RawSelector
-
- Selectable - Interface in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction(String, List<Selectable>) - Constructor for class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WritetimeOrTTL(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- SelectExpression - Class in org.apache.cassandra.cql
-
Select expressions are analogous to the projection in a SQL query.
- SelectExpression(Term, Term, int, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a range (slice) of columns.
- SelectExpression(Term, int, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a list of columns.
- selectFullRow - Variable in class org.apache.cassandra.db.DataRange
-
- Selection - Class in org.apache.cassandra.cql3.statements
-
- Selection(List<CFDefinition.Name>, List<ColumnSpecification>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selection
-
- Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.statements
-
- 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.cql
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(SelectExpression, boolean, String, String, ConsistencyLevel, WhereClause, int) - Constructor for class org.apache.cassandra.cql.SelectStatement
-
- SelectStatement - Class in org.apache.cassandra.cql3.statements
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(CFDefinition, int, SelectStatement.Parameters, Selection, Term) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
-
- SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.Parameters(Map<ColumnIdentifier, Boolean>, boolean, boolean, ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
-
- SelectStatement.RawStatement(CFName, SelectStatement.Parameters, List<RawSelector>, List<Relation>, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- SemanticVersion - Class in org.apache.cassandra.utils
-
Implements semantic versioning as defined at http://semver.org/.
- SemanticVersion(String) - Constructor for class org.apache.cassandra.utils.SemanticVersion
-
Parse a semantic version from a string.
- send(R) - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- 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_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.
- sendNotification(String, String, Object) - Method in class org.apache.cassandra.service.StorageService
-
Sends JMX notification to subscribers.
- sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendOneWay(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- sendReply(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
-
- sendRR(MessageOut, InetAddress, IAsyncCallback, long) - Method in class org.apache.cassandra.net.MessagingService
-
Send a non-mutation message to a given endpoint.
- sendRR(MessageOut<? extends IMutation>, InetAddress, AbstractWriteResponseHandler) - Method in class org.apache.cassandra.net.MessagingService
-
Send a mutation message to a given endpoint.
- sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendToHintedEndpoints(RowMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, 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.
- sendTreeRequests(Collection<InetAddress>) - Method in class org.apache.cassandra.repair.RepairJob
-
Send merkle tree request to every involved neighbor.
- sentMessage - Variable in class org.apache.cassandra.net.WriteCallbackInfo
-
- separator - Static variable in class org.apache.cassandra.io.sstable.Component
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
-
- sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
-
- SequentialWriter - Class in org.apache.cassandra.io.util
-
Adds buffering, mark, and fsyncing to OutputStream.
- SequentialWriter(File, int, boolean) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
-
- SequentialWriter.BufferedFileWriterMark - Class in org.apache.cassandra.io.util
-
Class to hold a mark to the position of the file
- SequentialWriter.BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
-
- serial_consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.cas_args
-
- serializationFlags() - Method in class org.apache.cassandra.db.Column
-
- serializationFlags() - Method in class org.apache.cassandra.db.CounterColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.CounterUpdateColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.DeletedColumn
-
- serializationFlags() - Method in class org.apache.cassandra.db.ExpiringColumn
-
- serialize(K, DataOutput) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
- serialize(ColumnFamily, DataOutput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serialize(Column, DataOutput) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serialize(ReplayPosition, DataOutput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serialize(DeletionInfo, DataOutput, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serialize(ColumnSlice, DataOutput, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serialize(IDiskAtomFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serialize(NamesQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serialize(DataOutput) - Method in class org.apache.cassandra.db.filter.QueryPath
-
- serialize(SliceQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.ListType
-
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.MapType
-
Creates the same output than serialize, but from the internal representation.
- serialize(List<Pair<ByteBuffer, Column>>) - Method in class org.apache.cassandra.db.marshal.SetType
-
- serialize(RangeTombstoneList, DataOutput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serialize(Row, DataOutput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serialize(RowIndexEntry, DataOutput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serialize(RowMutation, DataOutput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- serialize(RowPosition, DataOutput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serialize(TruncateResponse, DataOutput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serialize(WriteResponse, DataOutput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serialize(AbstractBounds<?>, DataOutput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serialize(String, DataOutput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serialize(Token, DataOutput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serialize(EchoMessage, DataOutput, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
-
- serialize(T, DataOutput) - Method in interface org.apache.cassandra.io.ISerializer
-
Serialize the specified type into the specified DataOutput instance.
- serialize(T, DataOutput, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- serialize(IndexSummary, DataOutputStream) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
-
- serialize(SSTableMetadata, Set<Integer>, DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serialize(DataOutputStream, int) - Method in class org.apache.cassandra.net.MessageOut
-
- serialize(RepairMessage, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serialize(SyncRequest, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serialize(ValidationRequest, DataOutput, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serialize(NodePair, DataOutput, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- serialize(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
-
Layout is: <n><s_1><b_1>...<s_n><b_n>
where:
n is the number of elements
s_i is the number of bytes composing the ith element
b_i is the s_i bytes composing the ith element
- serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- serialize(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
-
Layout is: <n><sk_1><k_1><sv_1><v_1>...<sk_n><k_n><sv_n><v_n>
where:
n is the number of elements
sk_i is the number of bytes composing the ith key k_i
k_i is the sk_i bytes composing the ith key
sv_i is the number of bytes composing the ith value v_i
v_i is the sv_i bytes composing the ith value
- serialize(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
-
Layout is: <n><s_1><b_1>...<s_n><b_n>
where:
n is the number of elements
s_i is the number of bytes composing the ith element
b_i is the s_i bytes composing the ith element
- serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- serialize(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- serialize(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- serialize(KeyCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
-
- serialize(RowCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
-
- serialize(Collection<RowMutation>, DataOutput, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serialize() - Method in class org.apache.cassandra.service.pager.PagingState
-
- serialize(Commit, DataOutput, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serialize(PrepareResponse, DataOutput, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serialize(StreamMessage, WritableByteChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- serialize(V, WritableByteChannel, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
-
- serialize(StreamRequest, DataOutput, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serialize(StreamSummary, DataOutput, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serialize(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event
-
- serialize(EnumSet<Frame.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
- serialize(Boolean, DataOutput, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serialize(EstimatedHistogram, DataOutput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serialize(TSerializer, TBase, DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Deprecated.
- serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- serialize(IFilter, DataOutput) - Static method in class org.apache.cassandra.utils.FilterFactory
-
- serialize(IntervalTree<C, D, I>, DataOutput, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serialize(MerkleTree, DataOutput, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serialize(DataOutput) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serialize(StreamingHistogram, DataOutput) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serialize(UUID, DataOutput, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
-
- serializeCfId(UUID, DataOutput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
-
- serializedSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializedSchema(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.Column
-
- serializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(ColumnFamily, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializedSize(Column, TypeSizes) - Method in class org.apache.cassandra.db.ColumnSerializer
-
- serializedSize(ReplayPosition, TypeSizes) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.CounterColumn
-
- serializedSize(DeletionInfo, TypeSizes, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(DeletionInfo, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- serializedSize(ColumnSlice, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
-
- serializedSize(IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
-
- serializedSize(NamesQueryFilter, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.filter.QueryPath
-
- serializedSize(SliceQueryFilter, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- serializedSize(TypeSizes) - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.RangeTombstone
-
- serializedSize(RangeTombstoneList, TypeSizes, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(RangeTombstoneList, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
-
- serializedSize(Row, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
-
- serializedSize() - Method in class org.apache.cassandra.db.RowIndexEntry
-
- serializedSize(RowMutation, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
-
- serializedSize(RowPosition, TypeSizes) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- serializedSize(ColumnFamily, TypeSizes, int) - Static method in class org.apache.cassandra.db.SuperColumns
-
- serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- serializedSize(WriteResponse, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- serializedSize(AbstractBounds<?>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serializedSize(Token, TypeSizes) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serializedSize(EchoMessage, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
-
- serializedSize(T, TypeSizes) - Method in interface org.apache.cassandra.io.ISerializer
-
- serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
-
- serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
-
- serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
-
- serializedSize(RepairMessage, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
-
- serializedSize(SyncRequest, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- serializedSize(ValidationRequest, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- serializedSize(NodePair, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
-
- serializedSize(Collection<RowMutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
-
- serializedSize(Commit, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
-
- serializedSize(StreamRequest, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- serializedSize(StreamSummary, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- serializedSize() - Method in class org.apache.cassandra.transport.Event
-
- serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
-
- serializedSize(EstimatedHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
-
- serializedSize() - Method in interface org.apache.cassandra.utils.IFilter
-
- serializedSize(IntervalTree<C, D, I>, TypeSizes, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
- serializedSize(MerkleTree, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
-
- serializedSize() - Method in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- serializedSize(TypeSizes) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- serializedSize(StreamingHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
-
- serializedSizeForSSTable() - Method in class org.apache.cassandra.db.Column
-
- serializedSizeForSSTable() - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- serializedSizeForSSTable() - Method in class org.apache.cassandra.db.RangeTombstone
-
- serializedValue - Variable in enum org.apache.cassandra.db.ReadCommand.Type
-
- serializedValueSize(Object) - Method in enum org.apache.cassandra.transport.DataType
-
- serializedValueSize(Object) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.SchemaChange
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.StatusChange
-
- serializeEvent(ChannelBuffer) - Method in class org.apache.cassandra.transport.Event.TopologyChange
-
- serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- serializeForSSTable(OnDiskAtom, DataOutput) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- serializeForSSTable(RangeTombstone, DataOutput) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- serializeForSSTable(T, DataOutput) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Serialize the specified type into the specified DataOutputStream
instance in the format suited for SSTables.
- serializer - Static variable in class org.apache.cassandra.db.Column
-
- serializer - Static variable in class org.apache.cassandra.db.ColumnFamily
-
- serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- serializer - Static variable in class org.apache.cassandra.db.CounterMutation
-
- serializer() - Static method in class org.apache.cassandra.db.DeletionInfo
-
- serializer - Static variable in class org.apache.cassandra.db.DeletionTime
-
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- serializer - Static variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- serializer - Static variable in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- serializer - Variable in class org.apache.cassandra.db.marshal.ListType
-
- serializer - Static variable in class org.apache.cassandra.db.PagedRangeCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceCommand
-
- serializer - Static variable in class org.apache.cassandra.db.RangeSliceReply
-
- serializer - Static variable in class org.apache.cassandra.db.RangeTombstone
-
- serializer - Static variable in class org.apache.cassandra.db.RangeTombstoneList
-
- serializer - Static variable in class org.apache.cassandra.db.ReadCommand
-
- serializer - Static variable in class org.apache.cassandra.db.ReadResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Row
-
- serializer - Static variable in class org.apache.cassandra.db.RowIndexEntry
-
- serializer - Static variable in class org.apache.cassandra.db.RowMutation
-
- serializer - Static variable in class org.apache.cassandra.db.RowPosition
-
- serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
-
- serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
-
- serializer - Static variable in class org.apache.cassandra.db.Truncation
-
- serializer - Static variable in class org.apache.cassandra.db.WriteResponse
-
- serializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
-
- serializer - Static variable in class org.apache.cassandra.dht.Token
-
- serializer - Static variable in class org.apache.cassandra.gms.EchoMessage
-
- serializer - Static variable in class org.apache.cassandra.gms.EndpointState
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigest
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck2
-
- serializer - Static variable in class org.apache.cassandra.gms.GossipDigestSyn
-
- serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- serializer - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
-
- serializer - Static variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- serializer - Variable in class org.apache.cassandra.net.CallbackInfo
-
- serializer - Variable in class org.apache.cassandra.net.MessageOut
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
- serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
-
- serializer - Static variable in class org.apache.cassandra.repair.NodePair
-
- serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
-
- serializer - Static variable in class org.apache.cassandra.service.paxos.PrepareResponse
-
- serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.CompleteMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.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
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
-
- serializer - Static variable in class org.apache.cassandra.streaming.StreamSummary
-
- serializer - Static variable in class org.apache.cassandra.utils.BooleanSerializer
-
- serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
-
- serializer(ISerializer<C>, ISerializer<D>, Constructor<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
-
- serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
-
- serializer - Static variable in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
-
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializeSuperColumnFamily(ColumnFamily, DataOutput, int) - Static method in class org.apache.cassandra.db.SuperColumns
-
- SerializingCache<K,V> - Class in org.apache.cassandra.cache
-
Serializes cache values off-heap.
- SerializingCacheProvider - Class in org.apache.cassandra.cache
-
- SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
-
- serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
-
- serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- Server - Class in org.apache.cassandra.transport
-
- Server(InetSocketAddress) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(String, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(InetAddress, int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server(int) - Constructor for class org.apache.cassandra.transport.Server
-
- Server.ConnectionTracker - Class in org.apache.cassandra.transport
-
- Server.ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
-
- server_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- ServerConnection - Class in org.apache.cassandra.transport
-
- ServerConnection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
-
- ServerError - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
-
- session - Variable in class org.apache.cassandra.repair.RepairFuture
-
- session - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- session - Variable in class org.apache.cassandra.streaming.StreamReader
-
- session - Variable in class org.apache.cassandra.streaming.StreamTask
-
StreamSession that this task belongs
- session - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SessionCompleteEventCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionCompleteEventCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
-
- sessionFailed() - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.SESSION_FAILED
message.
- SessionFailedMessage - Class in org.apache.cassandra.streaming.messages
-
- SessionFailedMessage() - Constructor for class org.apache.cassandra.streaming.messages.SessionFailedMessage
-
- sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
-
RepairSession id
- sessionId - Variable in class org.apache.cassandra.tracing.TraceState
-
- sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
-
- SessionInfo - Class in org.apache.cassandra.streaming
-
Stream session info.
- SessionInfo(InetAddress, Collection<StreamSummary>, Collection<StreamSummary>, StreamSession.State) - Constructor for class org.apache.cassandra.streaming.SessionInfo
-
- SessionInfoCompositeData - Class in org.apache.cassandra.streaming.management
-
- SessionInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionInfoCompositeData
-
- sessions - Variable in class org.apache.cassandra.streaming.StreamState
-
- SESSIONS_CF - Static variable in class org.apache.cassandra.tracing.Tracing
-
- sessionState - Static variable in class org.apache.cassandra.cli.CliMain
-
- set(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- set(double) - Method in class org.apache.cassandra.utils.DefaultDouble
-
- set(int) - Method in class org.apache.cassandra.utils.DefaultInteger
-
- set(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
Sets the bit at the specified index.
- set(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long, byte) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
-
- set(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Sets the bit at the specified index.
- set_cql_version(String, 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(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- set_cql_version(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
Deprecated.
This is now a no-op. Please use the CQL3 specific methods instead.
- set_cql_version(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
-
- set_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
-
- set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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
-
- 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
-
- setBound(ColumnIdentifier, Relation.Type, Term, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- setBoundVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
-
- setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setByte(long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- setBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from buffer to Memory
- setCacheCapacities(int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setCacheKeysToSave(int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- 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
-
- 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_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_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_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
-
- setColumnsLimit(int) - Method in class org.apache.cassandra.cql.SelectExpression
-
- setColumnsReversed(boolean) - Method in class org.apache.cassandra.cql.SelectExpression
-
- 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
-
- 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
-
- setCompactionStrategyClass(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionStrategyClass(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the compaction strategy by class name
- setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
Set the compaction threshold
- setCompactionThresholds(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCompactionThresholds(int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum and maximum number of SSTables in queue before compaction kicks off
- setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
-
- 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
-
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
set hadoop cassandra connection settings
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set hadoop cassandra connection settings
- 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_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
-
- 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
-
- setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.cql.Attributes
-
- setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Allows user to resize core pool size of the thread pool.
- setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- 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.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
-
- 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.SliceRange
-
- setCQLVersion(String) - Method in class org.apache.cassandra.service.ClientState
-
- setCrcCheckChance(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCrcCheckChance(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set new crc check chance
- setCrcCheckChance(double) - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- 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
-
- setDatacenter(String) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setDatacenterIsSet(boolean) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setDataIntegrityWriter(DataIntegrityMetadata.ChecksumWriter) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Turn on digest computation on this writer.
- 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
-
- setDeletion(Deletion) - Method in class org.apache.cassandra.thrift.Mutation
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
-
- setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
-
- setDeletionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Mutation
-
- setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
-
- 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
-
- 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
-
- setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- 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_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(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(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.SliceRange
-
- setFinish(ByteBuffer) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setFinishIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setGc_grace_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setGc_grace_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- 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
-
- setHost(String) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- setHostIsSet(boolean) - Method in class org.apache.cassandra.thrift.EndpointDetails
-
- 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
-
- 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_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
-
- 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
-
- setIndexBuilt() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexBuilt(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setIndexRemoved() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- setIndexRemoved(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setIndexType(IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- setInMemoryCompactionLimit(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setInputColumnFamily(Configuration, String, String, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace and column family for the input of this job.
- setInputColumns(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL columns for the input of this job.
- 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
-
- setInputMinSimultReqPerConnections(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.
- setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL user defined where clauses for the input of this job.
- setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
-
- 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_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_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
-
- 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_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
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.WhereClause
-
- setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- setKeyCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- 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
-
- 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.cli.CliClient
-
- setKeyspace(String) - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- setKeyspace(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
-
- setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
-
- 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
-
- 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
-
- setKeyType(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- 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
-
- 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
-
set read configuration settings
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
set read configuration settings
- setLog4jLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
-
- setLog4jLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
set the logging level at runtime
- setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- setMax_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMax_compaction_thresholdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMaxHintsInProgress(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintsInProgress(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaxHintWindow(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setMaxHintWindow(int) - Method in class org.apache.cassandra.service.StorageProxy
-
- setMaxHintWindow(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setMaximumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setMaximumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Sets the maximum number of sstables in queue before compaction kicks off
- setMaximumCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Allows user to resize maximum size of the thread pool.
- setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the validator thread pool.
- setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
-
- 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
-
- setMin_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
-
- setMin_compaction_thresholdIsSet(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
- setMultiKey(boolean) - Method in class org.apache.cassandra.cql.WhereClause
-
- 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) - 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
-
- 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
-
- setOpIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
-
- 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
-
- setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- setOutboundBindAny(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL prepared statement for the output of this job.
- setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace for the output of this job.
- setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setPartitioner(IPartitioner<?>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPartitioner(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set partition filter
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
- 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
-
- setPendingRanges(String, Multimap<Range<Token>, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- setPhiConvictThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setPhiConvictThreshold(double) - Method in class org.apache.cassandra.gms.FailureDetector
-
- setPhiConvictThreshold(double) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- setPopulate_io_cache_on_flush(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- setPopulate_io_cache_on_flushIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- 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
-
- setReplicate_on_write(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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
-
- setReversed(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- setReversedIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
-
- 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
-
- 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
-
- setRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- Sets - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for sets.
- Sets.Adder - Class in org.apache.cassandra.cql3
-
- Sets.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
-
- Sets.DelayedValue - Class in org.apache.cassandra.cql3
-
- Sets.DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
-
- Sets.Discarder - Class in org.apache.cassandra.cql3
-
- Sets.Discarder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
-
- Sets.Literal - Class in org.apache.cassandra.cql3
-
- Sets.Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Sets.Literal
-
- Sets.Marker - Class in org.apache.cassandra.cql3
-
- Sets.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
-
- Sets.Setter - Class in org.apache.cassandra.cql3
-
- Sets.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
-
- Sets.Value - Class in org.apache.cassandra.cql3
-
- Sets.Value(Set<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
-
- 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.
- setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
- setSlice_range(SliceRange) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- setSlice_rangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.SlicePredicate
-
- 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
-
- setStart(ByteBuffer) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- 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.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.AbstractCassandraStorage
-
StoreFunc methods
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set store configuration settings
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
-
set store configuration settings
- 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
-
- setStreamId(int) - Method in class org.apache.cassandra.transport.Message
-
- setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
- setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setSubcomparator_type(String) - Method in class org.apache.cassandra.thrift.CfDef
-
- setSubcomparator_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
-
- 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<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_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
-
- 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_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_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
-
- setThriftFramedTransportSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
-
Sets the socket timeout
- setTimestamp(Long) - Method in class org.apache.cassandra.cql.Attributes
-
- 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
-
- setTimeToLive(int) - Method in class org.apache.cassandra.cql.Attributes
-
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- 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
-
- setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
-
- setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- setTrackedBy(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- setTracker(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- 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) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
set the value to the position of the tuple
- SetType<T> - Class in org.apache.cassandra.db.marshal
-
- SetType(AbstractType<T>) - Constructor for class org.apache.cassandra.db.marshal.SetType
-
- 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.AbstractCassandraStorage
-
- 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_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_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() - Static method in class org.apache.cassandra.auth.Auth
-
Sets up Authenticator and Authorizer.
- setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Setup is called once upon system startup to initialize the IAuthorizer.
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- setup() - Method in class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
-
- 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
-
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
-
- setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
-
- setValidation_class(String) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setValidation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
-
- setValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- 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
-
- 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
-
- shouldClearLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- 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.FailureDetectorSourceFilter
-
- shouldInclude(InetAddress) - Method in interface org.apache.cassandra.dht.RangeStreamer.ISourceFilter
-
- shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- shouldPreheatPageCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- shouldPurge(DecoratedKey, long) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- shouldPurge(DecoratedKey, long) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- shouldReplicateOnWrite() - Method in class org.apache.cassandra.db.CounterMutation
-
- Shuffle - Class in org.apache.cassandra.tools
-
- Shuffle(String, int) - Constructor for class org.apache.cassandra.tools.Shuffle
-
- Shuffle(String, int, String, int, boolean, String, String) - Constructor for class org.apache.cassandra.tools.Shuffle
-
- shuffle(boolean, String) - Method in class org.apache.cassandra.tools.Shuffle
-
Create and distribute a new, randomized token to endpoint mapping.
- shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
-
Initiates the shutdown process for the allocator thread.
- shutdown() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
shuts down the CommitLogExecutor in an orderly fashion
- shutdown() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Releases any resources if this strategy is shutdown (when the CFS is reloaded after a schema change).
- shutdown() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- shutdown() - Method in class org.apache.cassandra.net.MessagingService
-
Wait for callbacks and don't allow any more to be created (since they could require writing hints)
- 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
-
- shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
-
This method shuts down all registered stages.
- shutdownNow() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
-
- shutdownNow() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
-
- signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- signal() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- signalAll() - Method in class org.apache.cassandra.utils.SimpleCondition
-
- SimpleAbstractColumnIterator - Class in org.apache.cassandra.db.columniterator
-
- SimpleAbstractColumnIterator() - Constructor for class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
-
- SimpleClient - Class in org.apache.cassandra.transport
-
- SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleCondition - Class in org.apache.cassandra.utils
-
- SimpleCondition() - Constructor for class org.apache.cassandra.utils.SimpleCondition
-
- simpleEqual(Term.Raw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
-
- SimpleSeedProvider - Class in org.apache.cassandra.locator
-
- SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
-
- SimpleSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that treats Strategy order as proximity,
allowing non-read-repaired reads to prefer a single endpoint, which improves
cache locality.
- SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
-
- SimpleStrategy - Class in org.apache.cassandra.locator
-
This class returns the nodes responsible for a given
key but does not respect rack awareness.
- SimpleStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleStrategy
-
- SinglePartitionPager - Interface in org.apache.cassandra.service.pager
-
Common interface to single partition queries (by slice and by name).
- singleton(T, Comparator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- SinkManager - Class in org.apache.cassandra.sink
-
- SinkManager() - Constructor for class org.apache.cassandra.sink.SinkManager
-
- size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- size() - Method in interface org.apache.cassandra.cache.ICache
-
- size() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- size() - Method in class org.apache.cassandra.cache.SerializingCache
-
- size() - Method in class org.apache.cassandra.cql3.ResultSet
-
- size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- size() - Method in class org.apache.cassandra.cql3.VariableSpecifications
-
- size() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- size() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the total number of bytes written to this stream so far.
- size() - Method in class org.apache.cassandra.io.util.Memory
-
- size - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Total size of cache, in bytes
- size - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
-
Total size of file cache, in bytes
- size() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- size() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- size() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- size() - Method in class org.apache.cassandra.utils.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.
- sizeInBytes() - Method in class org.apache.cassandra.service.FileCacheService
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeof(String) - Method in class org.apache.cassandra.db.TypeSizes
-
assumes UTF8
- sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfEnumValue(T) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfInet(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfLongString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfString(String) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringList(List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringMap(Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfStringToStringListMap(Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
-
- sizeofVInt(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
-
- sizeofWithLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeofWithShortLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
-
- sizeOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- sizeOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
-
- SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
-
- SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- skip(DataInput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Skips count
number of bytes in this InputStream.
- skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- skipBytesFully(DataInput, long) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- skipCorrupted - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- skipIndex(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
Skip the index
- skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- SkipNullRepresenter - Class in org.apache.cassandra.utils
-
- SkipNullRepresenter() - Constructor for class org.apache.cassandra.utils.SkipNullRepresenter
-
- skipPromotedIndex(DataInput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- skipShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- SlabAllocator - Class in org.apache.cassandra.utils
-
The SlabAllocator is a bump-the-pointer allocator that allocates
large (2MB by default) regions and then doles them out to threads that request
slices into the array.
- SlabAllocator() - Constructor for class org.apache.cassandra.utils.SlabAllocator
-
- 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
-
- sliceFilterToSC(CompositeType, SliceQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
-
- SliceFromReadCommand - Class in org.apache.cassandra.db
-
- SliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
-
- 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(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter(ColumnSlice[], boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
Constructor that accepts multiple slices.
- SliceQueryFilter(ColumnSlice[], boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
-
- SliceQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
-
- SliceQueryFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
-
- SliceQueryPager - Class in org.apache.cassandra.service.pager
-
Pager over a SliceFromReadCommand.
- 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
-
- SnappyCompressor - Class in org.apache.cassandra.io.compress
-
- SnappyCompressor() - Constructor for class org.apache.cassandra.io.compress.SnappyCompressor
-
- snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Take a snap shot of this columnfamily store.
- snapshot(String, String) - Method in class org.apache.cassandra.db.Keyspace
-
Take a snapshot of the specific column family, or the entire set of column families
if columnFamily is null with a given timestamp
- snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
-
- snapshot_name - Variable in class org.apache.cassandra.db.SnapshotCommand
-
- SNAPSHOT_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
-
- SnapshotCommand - Class in org.apache.cassandra.db
-
- SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
-
- snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Directories
-
- snapshotExists(String) - Method in class org.apache.cassandra.db.Keyspace
-
Check whether snapshots already exists for a given name.
- snapshotLeveledManifest(String) - Method in class org.apache.cassandra.db.Directories
-
Deprecated.
- snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- 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
-
- snapshotWithoutCFS(String, String) - Static method in class org.apache.cassandra.db.compaction.LegacyLeveledManifest
-
Deprecated.
Snapshot a CF without having to load the sstables in that directory
- snapshotWithoutFlush(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- SNITCH_PROPERTIES_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
-
- SnitchProperties - Class in org.apache.cassandra.locator
-
- SnitchProperties() - Constructor for class org.apache.cassandra.locator.SnitchProperties
-
- socket - Variable in class org.apache.cassandra.transport.Server
-
- 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
-
- spaceReclaimed(long) - Method in class org.apache.cassandra.db.DataTracker
-
- SPEC - Static variable in class org.apache.cassandra.utils.ObjectSizes
-
- 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(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Split a composite column names into it's components.
- split(T) - Method in class org.apache.cassandra.dht.AbstractBounds
-
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?),
where ? means that the same type of AbstractBounds is returned as the original.
- split(T) - Method in class org.apache.cassandra.dht.Bounds
-
- split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- split(T) - Method in class org.apache.cassandra.dht.Range
-
- split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
-
Splits the range containing the given token, if no tree limits would be
violated.
- splitSize - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ssl_storage_port - Variable in class org.apache.cassandra.config.Config
-
- SSLFactory - Class in org.apache.cassandra.security
-
A Factory for providing and setting up Client and Server SSL wrapped
Socket and ServerSocket
- SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
-
- SSLTransportFactory - Class in org.apache.cassandra.cli.transport
-
- SSLTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.SSLTransportFactory
-
- SSLTransportFactory - Class in org.apache.cassandra.thrift
-
- SSLTransportFactory() - Constructor for class org.apache.cassandra.thrift.SSLTransportFactory
-
- sstable - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- SSTable - Class in org.apache.cassandra.io.sstable
-
This class is built on top of the SequenceFile.
- SSTable(Descriptor, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- SSTable(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- sstable - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SSTABLE_ACTIVITY_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- SSTableActivityCF - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SSTableAddedNotification - Class in org.apache.cassandra.notifications
-
- SSTableAddedNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
-
- sstableComparator - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- sstableCompressor - Variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- SSTableDeletingNotification - Class in org.apache.cassandra.notifications
-
Fired right before removing an SSTable.
- SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
-
- SSTableDeletingTask - Class in org.apache.cassandra.io.sstable
-
- SSTableDeletingTask(SSTableReader) - Constructor for class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- SSTableExport - Class in org.apache.cassandra.tools
-
Export SSTables to JSON format.
- SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
-
- SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableImport - Class in org.apache.cassandra.tools
-
Create SSTables from JSON input
- SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(boolean, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- SSTableImport(Integer, boolean, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
-
- sstableLevel - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
-
- SSTableLevelResetter - Class in org.apache.cassandra.tools
-
Reset level to 0 on a given set of sstables
- SSTableLevelResetter() - Constructor for class org.apache.cassandra.tools.SSTableLevelResetter
-
- SSTableListChangedNotification - Class in org.apache.cassandra.notifications
-
- SSTableListChangedNotification(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- sstableLister() - Method in class org.apache.cassandra.db.Directories
-
- SSTableLoader - Class in org.apache.cassandra.io.sstable
-
Cassandra SSTable bulk loader.
- SSTableLoader(File, SSTableLoader.Client, OutputHandler) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
-
- SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
-
- SSTableLoader.Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- SSTableMetadata - Class in org.apache.cassandra.io.sstable
-
Metadata for a SSTable.
- SSTableMetadata.Collector - Class in org.apache.cassandra.io.sstable
-
- SSTableMetadata.SSTableMetadataSerializer - Class in org.apache.cassandra.io.sstable
-
- SSTableMetadata.SSTableMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
-
- SSTableMetadataViewer - Class in org.apache.cassandra.tools
-
Shows the contents of sstable metadata
- SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
-
- SSTableNamesIterator - Class in org.apache.cassandra.db.columniterator
-
- SSTableNamesIterator(SSTableReader, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- SSTableNamesIterator(SSTableReader, FileDataInput, DecoratedKey, SortedSet<ByteBuffer>, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.SSTable
-
- SSTableReader - Class in org.apache.cassandra.io.sstable
-
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.
- SSTableReader.EmptyCompactionScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableReader.EmptyCompactionScanner(String) - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.EmptyCompactionScanner
-
- SSTableReader.Operator - Class in org.apache.cassandra.io.sstable
-
TODO: Move someplace reusable
- SSTableReader.Operator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- SSTableReader.SizeComparator - Class in org.apache.cassandra.io.sstable
-
- SSTableReader.SizeComparator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.SizeComparator
-
- sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
-
- sstables - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
-
- SSTableScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
-
- SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that doesn't assume rows are in sorted order.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Create a new buffering writer.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that assumes rows are in (partitioner) sorted order.
- SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Create a new writer.
- SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- SSTableSliceIterator - Class in org.apache.cassandra.db.columniterator
-
A Column Iterator over SSTable
- SSTableSliceIterator(SSTableReader, DecoratedKey, ColumnSlice[], boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
An iterator for a slice within an SSTable
- sstablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Histogram of the number of sstable data files accessed per read
- SSTableSplitter - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
-
- SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplitController(ColumnFamilyStore, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.SplittingCompactionTask(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
-
- SSTableSplitter.StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- sstablesRewrite(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- SSTableWriter - Class in org.apache.cassandra.io.sstable
-
- SSTableWriter(String, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- SSTableWriter(String, long, CFMetaData, IPartitioner<?>, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- Stage - Enum in org.apache.cassandra.concurrent
-
- StageManager - Class in org.apache.cassandra.concurrent
-
This class manages executor services for Messages recieved: each Message requests
running on a specific "stage" for concurrency control; hence the Map approach,
even though stages (executors) are not created dynamically.
- StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
-
- StandaloneScrubber - Class in org.apache.cassandra.tools
-
- StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
-
- StandaloneSplitter - Class in org.apache.cassandra.tools
-
- StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
-
- StandaloneUpgrader - Class in org.apache.cassandra.tools
-
- StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
-
- start() - Method in class org.apache.cassandra.db.BatchlogManager
-
- start - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- start() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- start() - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- start - Variable in class org.apache.cassandra.db.PagedRangeCommand
-
- start(int) - Method in class org.apache.cassandra.gms.Gossiper
-
- start(int, Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.Gossiper
-
Start the gossiper with the generation number, preloading the map of application states before starting
- start() - Method in class org.apache.cassandra.repair.RequestCoordinator
-
- start - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Start the server.
- start() - Method in class org.apache.cassandra.service.CassandraDaemon
-
- start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
-
- start() - Method in class org.apache.cassandra.service.GCInspector
-
- start() - Method in class org.apache.cassandra.streaming.StreamSession
-
- start(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_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.SliceRange
-
- start() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- start() - Method in class org.apache.cassandra.transport.Server
-
- 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
-
- startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- startCompaction(ColumnFamilyStore, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Write compaction log, except columfamilies under system keyspace.
- started() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
report event on the size of the compaction.
- startGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startKey() - Method in class org.apache.cassandra.db.DataRange
-
- startNativeTransport() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- startNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startOf(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- startRpc() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- startRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- startup() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Performs any extra initialization required
- startup() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- StartupMessage - Class in org.apache.cassandra.transport.messages
-
The initial message of the protocol.
- StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
-
- state() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
-
- state() - Method in interface org.apache.cassandra.service.pager.QueryPager
-
Get the current state of the pager.
- state() - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
-
- state() - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
-
- state() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
-
- state - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Current session state
- state(StreamSession.State) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set current state to newState
.
- state() - Method in class org.apache.cassandra.streaming.StreamSession
-
- state() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- statement - Variable in class org.apache.cassandra.cql.CQLStatement
-
- statement - Variable in class org.apache.cassandra.cql.hooks.PreparationContext
-
- statement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- statements - Variable in class org.apache.cassandra.cql.BatchStatement
-
- StatementType - Enum in org.apache.cassandra.cql
-
- 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
-
- staticColumns() - Method in class org.apache.cassandra.cql3.CFDefinition
-
- staticDef(ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- STATS - Static variable in class org.apache.cassandra.io.sstable.Component
-
- status - Variable in class org.apache.cassandra.transport.Event.StatusChange
-
- STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- STATUS_RELOCATING - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- StatusLogger - Class in org.apache.cassandra.utils
-
- StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
-
- stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
-
- stop - Variable in class org.apache.cassandra.db.PagedRangeCommand
-
- stop() - Method in class org.apache.cassandra.gms.Gossiper
-
- stop() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Stop the client.
- stop() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
-
Stop the server.
- stop() - Method in class org.apache.cassandra.service.CassandraDaemon
-
Stop the daemon, ideally in an idempotent manner.
- stop(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
-
- stop() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- stop() - Method in class org.apache.cassandra.transport.Server
-
- 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
.
- stopDaemon() - Method in class org.apache.cassandra.service.StorageService
-
- stopDaemon() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopGossiping() - Method in class org.apache.cassandra.service.StorageService
-
- stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopKey() - Method in class org.apache.cassandra.db.DataRange
-
- stopNativeTransport() - Method in class org.apache.cassandra.service.StorageService
-
- stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopNonLocal(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
-
- stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- stopSession() - Method in class org.apache.cassandra.tracing.Tracing
-
Stop the session and record its complete.
- stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- stopTransports() - Method in class org.apache.cassandra.service.StorageService
-
- storage_port - Variable in class org.apache.cassandra.config.Config
-
- StorageMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Storage.
- StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
-
- StorageProxy - Class in org.apache.cassandra.service
-
- StorageProxy.WritePerformer - Interface in org.apache.cassandra.service
-
- StorageProxyMBean - Interface in org.apache.cassandra.service
-
- StorageService - Class in org.apache.cassandra.service
-
This abstraction contains the token/identifier of this node
on the identifier space.
- StorageService() - Constructor for class org.apache.cassandra.service.StorageService
-
- StorageServiceMBean - Interface in org.apache.cassandra.service
-
- store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- storeKeyspaceInstance(Keyspace) - Method in class org.apache.cassandra.config.Schema
-
Store given Keyspace instance to the schema
- storeSignature - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
-
- StreamEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent(StreamEvent.Type, UUID) - Constructor for class org.apache.cassandra.streaming.StreamEvent
-
- StreamEvent.ProgressEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.ProgressEvent(UUID, ProgressInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
-
- StreamEvent.SessionCompleteEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionCompleteEvent(StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- StreamEvent.SessionPreparedEvent - Class in org.apache.cassandra.streaming
-
- StreamEvent.SessionPreparedEvent(UUID, SessionInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
-
- StreamEvent.Type - Enum in org.apache.cassandra.streaming
-
- StreamEventHandler - Interface in org.apache.cassandra.streaming
-
- StreamEventJMXNotifier - Class in org.apache.cassandra.streaming.management
-
- StreamEventJMXNotifier() - Constructor for class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
-
- StreamException - Class in org.apache.cassandra.streaming
-
- StreamException(StreamState, String) - Constructor for class org.apache.cassandra.streaming.StreamException
-
- StreamException(StreamState, String, Throwable) - Constructor for class org.apache.cassandra.streaming.StreamException
-
- streamId - Variable in class org.apache.cassandra.transport.Frame.Header
-
- streaming_socket_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
-
- StreamingHistogram - Class in org.apache.cassandra.utils
-
Histogram that can be constructed from streaming of data.
- StreamingHistogram(int) - Constructor for class org.apache.cassandra.utils.StreamingHistogram
-
Creates a new histogram with max bin size of maxBinSize
- StreamingHistogram.StreamingHistogramSerializer - Class in org.apache.cassandra.utils
-
- StreamingHistogram.StreamingHistogramSerializer() - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
-
- StreamingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for streaming.
- StreamingMetrics(InetAddress) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
-
- StreamingRepairTask - Class in org.apache.cassandra.repair
-
Task that make two nodes exchange (stream) some ranges (for a given table/cf).
- StreamingRepairTask(RepairJobDesc, SyncRequest) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
-
- StreamInitMessage - Class in org.apache.cassandra.streaming.messages
-
StreamInitMessage is first sent from the node where
StreamSession
is started,
to initiate corresponding
StreamSession
on the other side.
- StreamInitMessage(InetAddress, UUID, String, boolean) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- 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
-
- StreamManagerMBean - Interface in org.apache.cassandra.streaming
-
- StreamMessage - Class in org.apache.cassandra.streaming.messages
-
StreamMessage is an abstract base class that every messages in streaming protocol inherit.
- StreamMessage(StreamMessage.Type) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessage
-
- StreamMessage.Serializer<V extends StreamMessage> - Interface in org.apache.cassandra.streaming.messages
-
StreamMessage serializer
- StreamMessage.Type - Enum in org.apache.cassandra.streaming.messages
-
StreamMessage types
- StreamPlan - Class in org.apache.cassandra.streaming
-
StreamPlan
is a helper class that builds StreamOperation of given configuration.
- StreamPlan(String) - Constructor for class org.apache.cassandra.streaming.StreamPlan
-
Start building stream plan.
- StreamReader - Class in org.apache.cassandra.streaming
-
StreamReader reads from stream and writes to SSTable.
- StreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamReader
-
- StreamReceiveTask - Class in org.apache.cassandra.streaming
-
Task that manages receiving files for the session for certain ColumnFamily.
- StreamReceiveTask(StreamSession, UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
-
- StreamRequest - Class in org.apache.cassandra.streaming
-
- StreamRequest(String, Collection<Range<Token>>, Collection<String>) - Constructor for class org.apache.cassandra.streaming.StreamRequest
-
- StreamRequest.StreamRequestSerializer - Class in org.apache.cassandra.streaming
-
- StreamRequest.StreamRequestSerializer() - Constructor for class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
-
- StreamResultFuture - Class in org.apache.cassandra.streaming
-
A future on the result (
StreamState
) of a streaming plan.
- StreamSession - Class in org.apache.cassandra.streaming
-
Handles the streaming a one or more section of one of more sstables to and from a specific
remote node.
- StreamSession(InetAddress) - Constructor for class org.apache.cassandra.streaming.StreamSession
-
Create new streaming session with the peer.
- StreamSession.SSTableStreamingSections - Class in org.apache.cassandra.streaming
-
- StreamSession.SSTableStreamingSections(SSTableReader, List<Pair<Long, Long>>, long) - Constructor for class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
-
- StreamSession.State - Enum in org.apache.cassandra.streaming
-
- StreamState - Class in org.apache.cassandra.streaming
-
Current snapshot of streaming progress.
- StreamState(UUID, String, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
-
- StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
-
- StreamSummary - Class in org.apache.cassandra.streaming
-
Summary of streaming.
- StreamSummary(UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamSummary
-
- StreamSummary.StreamSummarySerializer - Class in org.apache.cassandra.streaming
-
- StreamSummary.StreamSummarySerializer() - Constructor for class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
-
- StreamSummaryCompositeData - Class in org.apache.cassandra.streaming.management
-
- StreamSummaryCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
-
- StreamTask - Class in org.apache.cassandra.streaming
-
StreamTask is an abstraction of the streaming task performed over specific ColumnFamily.
- StreamTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTask
-
- StreamTransferTask - Class in org.apache.cassandra.streaming
-
StreamTransferTask sends sections of SSTable files in certain ColumnFamily.
- StreamTransferTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
-
- StreamWriter - Class in org.apache.cassandra.streaming
-
StreamWriter writes given section of the SSTable to given channel.
- StreamWriter(SSTableReader, Collection<Pair<Long, Long>>, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamWriter
-
- string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyCollectionsParameters(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- stringifyTypeParameters(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- StringToken - Class in org.apache.cassandra.dht
-
- StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
-
- subcodec - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- subcomparator_type - Variable in class org.apache.cassandra.thrift.CfDef
-
- submit(Callable<T>) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
-
- submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Call this whenever a compaction might be needed on the given columnfamily.
- submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitDifferencers() - Method in class org.apache.cassandra.repair.RepairJob
-
Submit differencers for running.
- submitHint(RowMutation, InetAddress, AbstractWriteResponseHandler) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Is not scheduled, because it is performing disjoint work from sstable compaction.
- submitMaximal(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitRepairSession(Range<Token>, String, boolean, Collection<String>, Collection<String>, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Requests repairs for the given keyspace and column families.
- submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitValidation(ColumnFamilyStore, Validator) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Does not mutate data, so is not scheduled.
- submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- subName(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
-
- subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.DataTracker
-
- subscribers - Variable in class org.apache.cassandra.db.DataTracker
-
- subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- success - Variable in class org.apache.cassandra.db.TruncateResponse
-
- success - Variable in class org.apache.cassandra.repair.messages.SyncComplete
-
true if sync success, false otherwise
- success - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
-
true if validation success, false otherwise
- success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
-
- 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_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
-
- sum() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
-
- sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
-
Calculates estimated number of points in interval [-inf,b].
- summaries - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
-
Summaries of streaming out
- SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
-
- 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.
- superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
-
- SuperColumns - Class in org.apache.cassandra.db
-
- SuperColumns() - Constructor for class org.apache.cassandra.db.SuperColumns
-
- SuperColumns.SCFilter - Class in org.apache.cassandra.db
-
- SuperColumns.SCFilter(ByteBuffer, IDiskAtomFilter) - Constructor for class org.apache.cassandra.db.SuperColumns.SCFilter
-
- supersedes(RangeTombstone, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.RangeTombstone
-
This tombstone supersedes another one if it is more recent and cover a
bigger range than rt.
- SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.Auth
-
- supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
-
- SupportedMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
-
- supportedOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- supportedOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Set of options supported by CREATE USER and ALTER USER queries.
- supportedOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- switchLock - Static variable in class org.apache.cassandra.db.Keyspace
-
accesses to CFS.memtable should acquire this for thread safety.
- switchMemtable(boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Switch and flush the current memtable, if it was dirty.
- switchMemtable() - Method in class org.apache.cassandra.db.DataTracker
-
Switch the current memtable.
- sync() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Forces a disk flush on the commit log files that need it.
- sync() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Forces a disk flush for this segment file.
- sync() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- sync() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Synchronize file contents with disk.
- SYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer
-
- SyncComplete - Class in org.apache.cassandra.repair.messages
-
- SyncComplete(RepairJobDesc, NodePair, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- SyncComplete(RepairJobDesc, InetAddress, InetAddress, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
-
- syncComplete(RepairJobDesc, NodePair, boolean) - Method in class org.apache.cassandra.repair.RepairSession
-
Notify this session that sync completed/failed with given NodePair
.
- syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- syncNeeded - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- SyncRequest - Class in org.apache.cassandra.repair.messages
-
Body part of SYNC_REQUEST repair message.
- SyncRequest(RepairJobDesc, InetAddress, InetAddress, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
-
- SyncRequest.SyncRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- SyncRequest.SyncRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
-
- SyntaxException - Exception in org.apache.cassandra.exceptions
-
- SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
-
- SYS_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- system() - Static method in class org.apache.cassandra.db.Keyspace
-
- system_add_column_family(CfDef, 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(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(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- SYSTEM_KS - Static variable in class org.apache.cassandra.db.Keyspace
-
- system_update_column_family(CfDef, 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(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(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- 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(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(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
update an existing keyspace, but do not allow column family modifications.
- systemKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
-
- SystemKeyspace - Class in org.apache.cassandra.db
-
- SystemKeyspace() - Constructor for class org.apache.cassandra.db.SystemKeyspace
-
- SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
-
- systemKeyspaceNames - Static variable in class org.apache.cassandra.config.Schema
-
- validate() - Method in class org.apache.cassandra.config.CFMetaData
-
- validate() - Method in class org.apache.cassandra.config.KSMetaData
-
- validate() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- validate() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating, and must be called prior to access.
- validate(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.AlterTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- 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.CreateIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating.
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
-
- validate() - 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.ListUsersStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- validate() - Method in class org.apache.cassandra.cql3.UserOptions
-
- validate(Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
-
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- validate() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.AsciiSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UTF8Serializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- 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_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.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.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(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateCellNames(Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative validation function used by CollectionsType in conjunction with CompositeType.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validateColumn(CFMetaData, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateColumnData(CFMetaData, Column, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
Validates the data part of the column (everything in the Column object but the name, which is assumed to be valid)
- validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnName(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnOrSuperColumn(CFMetaData, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnParent(CFMetaData, ColumnParent) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateColumnPath(CFMetaData, ColumnPath) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
validates all parts of the path to the column, including the column name
- validateColumns(Iterable<Column>) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateCompactionOptions(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.config.CFMetaData
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
-
Like getComparator, but validates that @param i does not exceed the defined range
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
-
- validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
-
- validateCompatility(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Validates configuration of IAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Validates configuration of IAuthorizer implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Validates configuration of IInternodeAuthenticator implementation (if configurable).
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
- validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.Column
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.CounterColumn
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.DeletedColumn
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.ExpiringColumn
-
- validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.OnDiskAtom
-
- validateFields(CFMetaData) - Method in class org.apache.cassandra.db.RangeTombstone
-
- validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForCasCommit(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForRead(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateForWrite(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
- validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyAlias(CFMetaData, String) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspace(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotSystem(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyspaceNotYetExisting(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateLogin() - Method in class org.apache.cassandra.service.ClientState
-
- validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
-
- validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateName(CFMetaData) - Method in class org.apache.cassandra.db.Column
-
- validateNewMessage(Message.Type, int, int) - Method in class org.apache.cassandra.transport.ServerConnection
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
- validateOptions() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
-
- validateOptions() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Validates the index_options passed in the ColumnDef
- validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- 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.
- ValidationRequest - Class in org.apache.cassandra.repair.messages
-
ValidationRequest
- ValidationRequest(RepairJobDesc, int) - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest
-
- ValidationRequest.ValidationRequestSerializer - Class in org.apache.cassandra.repair.messages
-
- ValidationRequest.ValidationRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
-
- validator - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- validator - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- Validator - Class in org.apache.cassandra.repair
-
Handles the building of a merkle tree for a column family.
- Validator(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.Validator
-
Create Validator with default size of initial Merkle Tree.
- Validator(RepairJobDesc, InetAddress, MerkleTree, int) - Constructor for class org.apache.cassandra.repair.Validator
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- value - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
-
- value - Variable in class org.apache.cassandra.db.Column
-
- value() - Method in class org.apache.cassandra.db.Column
-
- value - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
-
- value - Variable in class org.apache.cassandra.gms.VersionedValue
-
- value - 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.DefaultDouble
-
- 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
-
- valueFactory - Variable in class org.apache.cassandra.service.StorageService
-
- valueOf(String) - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.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.RequestSchedulerId
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.Relation.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.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.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.RowPosition.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.WriteType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.gms.ApplicationState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.hadoop.pig.AbstractCassandraStorage.MarshallerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.thrift.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_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.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.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.RequestType
-
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.transport.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.SchemaChange.Change
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.auth.Permission
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.SpeculativeRetry.RetryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ColumnDefinition.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.Config.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.RequestSchedulerId
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.ReadRepairDecision
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Constants.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.Relation.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.BatchStatement.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - 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(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.Restriction.EQ
-
- values(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.Restriction.Slice
-
- values(List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- values() - Static method in enum org.apache.cassandra.db.ColumnFamilyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ColumnSerializer.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.compaction.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.ConsistencyLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.db.marshal.MapType
-
- values() - Static method in enum org.apache.cassandra.db.ReadCommand.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.RowPosition.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.SystemKeyspace.BootstrapState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.db.WriteType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.gms.ApplicationState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.hadoop.pig.AbstractCassandraStorage.MarshallerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.Component.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.net.MessagingService.Verb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.serializers.MapSerializer
-
- values() - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.service.CacheService.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.streaming.StreamSession.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.thrift.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_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.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.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.RequestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.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.transport.DataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Event.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.Message.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.SchemaChange.Change
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- values() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
-
- 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
-
- variables - Variable in class org.apache.cassandra.cql.hooks.ExecutionContext
-
- variables - Variable in class org.apache.cassandra.cql3.UpdateParameters
-
- VariableSpecifications - Class in org.apache.cassandra.cql3
-
- VariableSpecifications(List<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.VariableSpecifications
-
- verb - Variable in class org.apache.cassandra.net.MessageIn
-
- verb - Variable in class org.apache.cassandra.net.MessageOut
-
- verbose - Variable in class org.apache.cassandra.cli.CliSessionState
-
- verbSerializers - Static variable in class org.apache.cassandra.net.MessagingService
-
Messages we receive in IncomingTcpConnection have a Verb that tells us what kind of message it is.
- verbStages - Static variable in class org.apache.cassandra.net.MessagingService
-
- verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- version - Variable in class org.apache.cassandra.gms.VersionedValue
-
- version - Variable in class org.apache.cassandra.io.sstable.Descriptor
-
version has the following format: [a-z]+
- version - Variable in class org.apache.cassandra.net.MessageIn
-
- version - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable version
- version - Variable in class org.apache.cassandra.thrift.Cassandra.set_cql_version_args
-
- VERSION - Static variable in class org.apache.cassandra.thrift.cassandraConstants
-
- version - Variable in class org.apache.cassandra.transport.Frame.Header
-
- VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VersionedValue - Class in org.apache.cassandra.gms
-
This abstraction represents the state associated with a particular node which an
application wants to make available to the rest of the nodes in the cluster.
- VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
-
- VersionedValue.VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- VersionGenerator - Class in org.apache.cassandra.gms
-
A unique version number generator for any state that is generated by the
local node.
- VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
-
- VINT - Static variable in class org.apache.cassandra.db.TypeSizes
-