Modifier and Type | Field and Description |
---|---|
protected ConsistencyLevel |
AbstractModification.cLevel |
protected ConsistencyLevel |
BatchStatement.consistency |
static ConsistencyLevel |
AbstractModification.defaultConsistency |
Modifier and Type | Method and Description |
---|---|
ConsistencyLevel |
AbstractModification.getConsistencyLevel() |
ConsistencyLevel |
Attributes.getConsistencyLevel() |
ConsistencyLevel |
BatchStatement.getConsistencyLevel() |
ConsistencyLevel |
SelectStatement.getConsistencyLevel() |
ConsistencyLevel |
UpdateStatement.getConsistencyLevel()
Returns the consistency level of this
UPDATE statement, either
one parsed from the CQL statement, or the default level otherwise. |
Modifier and Type | Method and Description |
---|---|
void |
Attributes.setConsistencyLevel(ConsistencyLevel cLevel) |
Constructor and Description |
---|
AbstractModification(java.lang.String keyspace,
java.lang.String columnFamily,
java.lang.String keyAlias,
ConsistencyLevel cLevel,
java.lang.Long timestamp,
int timeToLive) |
Attributes(ConsistencyLevel cLevel,
java.lang.Long timestamp,
int timeToLive) |
SelectStatement(SelectExpression expression,
boolean isCountOper,
java.lang.String keyspace,
java.lang.String columnFamily,
ConsistencyLevel cLevel,
WhereClause clause,
int numRecords) |
Modifier and Type | Method and Description |
---|---|
ConsistencyLevel |
QueryOptions.getConsistency() |
ConsistencyLevel |
QueryOptions.getSerialConsistency()
Serial consistency for conditional updates.
|
Modifier and Type | Method and Description |
---|---|
static UntypedResultSet |
QueryProcessor.process(java.lang.String query,
ConsistencyLevel cl) |
static ResultMessage |
QueryProcessor.process(java.lang.String queryString,
ConsistencyLevel cl,
QueryState queryState) |
static ResultMessage |
QueryProcessor.processBatch(BatchStatement batch,
ConsistencyLevel cl,
QueryState queryState,
java.util.List<java.util.List<java.nio.ByteBuffer>> variables) |
Constructor and Description |
---|
QueryOptions(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values) |
QueryOptions(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values,
boolean skipMetadata,
int pageSize,
PagingState pagingState,
ConsistencyLevel serialConsistency) |
Modifier and Type | Method and Description |
---|---|
void |
BatchStatement.executeWithPerStatementVariables(ConsistencyLevel cl,
QueryState queryState,
java.util.List<java.util.List<java.nio.ByteBuffer>> variables) |
java.util.Collection<? extends IMutation> |
ModificationStatement.getMutations(java.util.List<java.nio.ByteBuffer> variables,
boolean local,
ConsistencyLevel cl,
long now,
boolean isBatch)
Convert statement into a list of mutations to apply on the server
|
protected java.util.Map<java.nio.ByteBuffer,ColumnGroupMap> |
ModificationStatement.readRequiredRows(java.util.List<java.nio.ByteBuffer> partitionKeys,
ColumnNameBuilder clusteringPrefix,
boolean local,
ConsistencyLevel cl) |
Modifier and Type | Method and Description |
---|---|
ConsistencyLevel |
CounterMutation.consistency() |
static ConsistencyLevel |
ConsistencyLevel.fromCode(int code) |
static ConsistencyLevel |
ConsistencyLevel.valueOf(java.lang.String name)
Returns the enum constant of this type with the specified name.
|
static ConsistencyLevel[] |
ConsistencyLevel.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Constructor and Description |
---|
CounterMutation(RowMutation rowMutation,
ConsistencyLevel consistency) |
Modifier and Type | Field and Description |
---|---|
ConsistencyLevel |
RequestTimeoutException.consistency |
ConsistencyLevel |
UnavailableException.consistency |
Constructor and Description |
---|
ReadTimeoutException(ConsistencyLevel consistency,
int received,
int blockFor,
boolean dataPresent) |
RequestTimeoutException(ExceptionCode code,
ConsistencyLevel consistency,
int received,
int blockFor) |
UnavailableException(ConsistencyLevel consistency,
int required,
int alive) |
WriteTimeoutException(WriteType writeType,
ConsistencyLevel consistency,
int received,
int blockFor) |
Modifier and Type | Method and Description |
---|---|
AbstractWriteResponseHandler |
AbstractReplicationStrategy.getWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints,
java.util.Collection<java.net.InetAddress> pendingEndpoints,
ConsistencyLevel consistency_level,
java.lang.Runnable callback,
WriteType writeType) |
Modifier and Type | Field and Description |
---|---|
protected ConsistencyLevel |
AbstractWriteResponseHandler.consistencyLevel |
Modifier and Type | Method and Description |
---|---|
void |
StorageProxy.WritePerformer.apply(IMutation mutation,
java.lang.Iterable<java.net.InetAddress> targets,
AbstractWriteResponseHandler responseHandler,
java.lang.String localDataCenter,
ConsistencyLevel consistency_level) |
static ColumnFamily |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
java.nio.ByteBuffer key,
ColumnNameBuilder prefix,
ColumnFamily expected,
ColumnFamily updates,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit)
Apply @param updates if and only if the current values in the row for @param key
match the ones given by @param expected.
|
static java.util.List<Row> |
StorageProxy.getRangeSlice(AbstractRangeCommand command,
ConsistencyLevel consistency_level) |
static AbstractReadExecutor |
AbstractReadExecutor.getReadExecutor(ReadCommand command,
ConsistencyLevel consistency_level) |
static void |
StorageProxy.mutate(java.util.Collection<? extends IMutation> mutations,
ConsistencyLevel consistency_level)
Use this method to have these Mutations applied
across all replicas.
|
static void |
StorageProxy.mutateAtomically(java.util.Collection<RowMutation> mutations,
ConsistencyLevel consistency_level)
See mutate.
|
static void |
StorageProxy.mutateWithTriggers(java.util.Collection<? extends IMutation> mutations,
ConsistencyLevel consistencyLevel,
boolean mutateAtomically) |
static AbstractWriteResponseHandler |
StorageProxy.performWrite(IMutation mutation,
ConsistencyLevel consistency_level,
java.lang.String localDataCenter,
StorageProxy.WritePerformer performer,
java.lang.Runnable callback,
WriteType writeType)
Perform the write of a mutation given a WritePerformer.
|
static java.util.List<Row> |
StorageProxy.read(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level)
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
|
static void |
StorageProxy.sendToHintedEndpoints(RowMutation rm,
java.lang.Iterable<java.net.InetAddress> targets,
AbstractWriteResponseHandler responseHandler,
java.lang.String localDataCenter,
ConsistencyLevel consistency_level)
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node
is not available.
|
static java.util.concurrent.Future<java.lang.Void> |
StorageProxy.submitHint(RowMutation mutation,
java.net.InetAddress target,
AbstractWriteResponseHandler responseHandler,
ConsistencyLevel consistencyLevel) |
Constructor and Description |
---|
AbstractWriteResponseHandler(Keyspace keyspace,
java.util.Collection<java.net.InetAddress> naturalEndpoints,
java.util.Collection<java.net.InetAddress> pendingEndpoints,
ConsistencyLevel consistencyLevel,
java.lang.Runnable callback,
WriteType writeType) |
DatacenterSyncWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints,
java.util.Collection<java.net.InetAddress> pendingEndpoints,
ConsistencyLevel consistencyLevel,
Keyspace keyspace,
java.lang.Runnable callback,
WriteType writeType) |
DatacenterWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints,
java.util.Collection<java.net.InetAddress> pendingEndpoints,
ConsistencyLevel consistencyLevel,
Keyspace keyspace,
java.lang.Runnable callback,
WriteType writeType) |
ReadCallback(IResponseResolver<TMessage,TResolved> resolver,
ConsistencyLevel consistencyLevel,
IReadCommand command,
java.util.List<java.net.InetAddress> filteredEndpoints)
Constructor when response count has to be calculated and blocked for.
|
WriteResponseHandler(java.util.Collection<java.net.InetAddress> writeEndpoints,
java.util.Collection<java.net.InetAddress> pendingEndpoints,
ConsistencyLevel consistencyLevel,
Keyspace keyspace,
java.lang.Runnable callback,
WriteType writeType) |
Modifier and Type | Method and Description |
---|---|
static int |
QueryPagers.countPaged(java.lang.String keyspace,
java.lang.String columnFamily,
java.nio.ByteBuffer key,
SliceQueryFilter filter,
ConsistencyLevel consistencyLevel,
int pageSize,
long now)
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
|
static QueryPager |
QueryPagers.pager(Pageable command,
ConsistencyLevel consistencyLevel) |
static QueryPager |
QueryPagers.pager(Pageable command,
ConsistencyLevel consistencyLevel,
PagingState state) |
protected java.util.List<Row> |
RangeNamesQueryPager.queryNextPage(int pageSize,
ConsistencyLevel consistencyLevel,
boolean localQuery) |
protected java.util.List<Row> |
RangeSliceQueryPager.queryNextPage(int pageSize,
ConsistencyLevel consistencyLevel,
boolean localQuery) |
protected java.util.List<Row> |
SliceQueryPager.queryNextPage(int pageSize,
ConsistencyLevel consistencyLevel,
boolean localQuery) |
Modifier and Type | Method and Description |
---|---|
static ConsistencyLevel |
ThriftConversion.fromThrift(org.apache.cassandra.thrift.ConsistencyLevel cl) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Map<DecoratedKey,ColumnFamily> |
CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level) |
Modifier and Type | Method and Description |
---|---|
static ConsistencyLevel |
CBUtil.readConsistencyLevel(org.jboss.netty.buffer.ChannelBuffer cb) |
Modifier and Type | Method and Description |
---|---|
static org.jboss.netty.buffer.ChannelBuffer |
CBUtil.consistencyLevelToCB(ConsistencyLevel consistency) |
ResultMessage |
SimpleClient.execute(java.lang.String query,
ConsistencyLevel consistency) |
ResultMessage |
SimpleClient.execute(java.lang.String query,
java.util.List<java.nio.ByteBuffer> values,
ConsistencyLevel consistencyLevel) |
ResultMessage |
SimpleClient.executePrepared(byte[] statementId,
java.util.List<java.nio.ByteBuffer> values,
ConsistencyLevel consistency) |
Modifier and Type | Field and Description |
---|---|
ConsistencyLevel |
BatchMessage.consistency |
Constructor and Description |
---|
BatchMessage(BatchStatement.Type type,
java.util.List<java.lang.Object> queryOrIdList,
java.util.List<java.util.List<java.nio.ByteBuffer>> values,
ConsistencyLevel consistency) |
ExecuteMessage(byte[] statementId,
java.util.List<java.nio.ByteBuffer> values,
ConsistencyLevel consistency) |
QueryMessage(java.lang.String query,
ConsistencyLevel consistency) |
Copyright © 2013 The Apache Software Foundation