Uses of Class
org.apache.cassandra.db.ConsistencyLevel

Packages that use ConsistencyLevel
org.apache.cassandra.cql   
org.apache.cassandra.cql3   
org.apache.cassandra.cql3.statements   
org.apache.cassandra.db   
org.apache.cassandra.exceptions   
org.apache.cassandra.locator   
org.apache.cassandra.service   
org.apache.cassandra.thrift   
org.apache.cassandra.transport   
org.apache.cassandra.transport.messages   
 

Uses of ConsistencyLevel in org.apache.cassandra.cql
 

Fields in org.apache.cassandra.cql declared as ConsistencyLevel
protected  ConsistencyLevel AbstractModification.cLevel
           
protected  ConsistencyLevel BatchStatement.consistency
           
static ConsistencyLevel AbstractModification.defaultConsistency
           
 

Methods in org.apache.cassandra.cql that return ConsistencyLevel
 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.
 

Methods in org.apache.cassandra.cql with parameters of type ConsistencyLevel
 void Attributes.setConsistencyLevel(ConsistencyLevel cLevel)
           
 

Constructors in org.apache.cassandra.cql with parameters of type ConsistencyLevel
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)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.cql3
 

Methods in org.apache.cassandra.cql3 that return ConsistencyLevel
 ConsistencyLevel CFPropDefs.getConsistencyLevel(java.lang.String key)
           
 

Methods in org.apache.cassandra.cql3 with parameters of type ConsistencyLevel
 ResultMessage CQLStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
          Execute the statement and return the resulting result or null if there is no result.
static ResultMessage QueryProcessor.process(java.lang.String queryString, ConsistencyLevel cl, QueryState queryState)
           
static ResultMessage QueryProcessor.processPrepared(CQLStatement statement, ConsistencyLevel cl, QueryState queryState, java.util.List<java.nio.ByteBuffer> variables)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.cql3.statements
 

Fields in org.apache.cassandra.cql3.statements declared as ConsistencyLevel
static ConsistencyLevel ModificationStatement.defaultConsistency
           
 

Methods in org.apache.cassandra.cql3.statements with parameters of type ConsistencyLevel
 ResultMessage AuthenticationStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage AuthorizationStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage ModificationStatement.execute(ConsistencyLevel cl, QueryState queryState, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage SchemaAlteringStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage.Rows SelectStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage TruncateStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 ResultMessage UseStatement.execute(ConsistencyLevel cl, QueryState state, java.util.List<java.nio.ByteBuffer> variables)
           
 java.util.Collection<? extends IMutation> BatchStatement.getMutations(java.util.List<java.nio.ByteBuffer> variables, boolean local, ConsistencyLevel cl, long now)
           
 java.util.Collection<RowMutation> DeleteStatement.getMutations(java.util.List<java.nio.ByteBuffer> variables, boolean local, ConsistencyLevel cl, long now)
           
protected abstract  java.util.Collection<? extends IMutation> ModificationStatement.getMutations(java.util.List<java.nio.ByteBuffer> variables, boolean local, ConsistencyLevel cl, long now)
          Convert statement into a list of mutations to apply on the server
 java.util.Collection<IMutation> UpdateStatement.getMutations(java.util.List<java.nio.ByteBuffer> variables, boolean local, ConsistencyLevel cl, long now)
          Convert statement into a list of mutations to apply on the server
protected  java.util.Map<java.nio.ByteBuffer,ColumnGroupMap> ModificationStatement.readRows(java.util.List<java.nio.ByteBuffer> keys, ColumnNameBuilder builder, java.util.Set<java.nio.ByteBuffer> toRead, CompositeType composite, boolean local, ConsistencyLevel cl)
           
protected  void BatchStatement.validateConsistency(ConsistencyLevel cl)
           
protected  void DeleteStatement.validateConsistency(ConsistencyLevel cl)
           
protected abstract  void ModificationStatement.validateConsistency(ConsistencyLevel cl)
           
protected  void UpdateStatement.validateConsistency(ConsistencyLevel cl)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.db
 

Methods in org.apache.cassandra.db that return ConsistencyLevel
 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.
 

Constructors in org.apache.cassandra.db with parameters of type ConsistencyLevel
CounterMutation(RowMutation rowMutation, ConsistencyLevel consistency)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.exceptions
 

Fields in org.apache.cassandra.exceptions declared as ConsistencyLevel
 ConsistencyLevel RequestTimeoutException.consistency
           
 ConsistencyLevel UnavailableException.consistency
           
 

Constructors in org.apache.cassandra.exceptions with parameters of type ConsistencyLevel
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)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.locator
 

Methods in org.apache.cassandra.locator with parameters of type ConsistencyLevel
 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)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.service
 

Fields in org.apache.cassandra.service declared as ConsistencyLevel
protected  ConsistencyLevel AbstractWriteResponseHandler.consistencyLevel
           
protected  ConsistencyLevel ReadCallback.consistencyLevel
           
 

Methods in org.apache.cassandra.service with parameters of type ConsistencyLevel
 void StorageProxy.WritePerformer.apply(IMutation mutation, java.lang.Iterable<java.net.InetAddress> targets, AbstractWriteResponseHandler responseHandler, java.lang.String localDataCenter, ConsistencyLevel consistency_level)
           
static java.util.List<Row> StorageProxy.getRangeSlice(RangeSliceCommand 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 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 java.util.concurrent.Future<java.lang.Void> StorageProxy.scheduleLocalHint(RowMutation mutation, java.net.InetAddress target, AbstractWriteResponseHandler responseHandler, ConsistencyLevel consistencyLevel)
           
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.
 

Constructors in org.apache.cassandra.service with parameters of type ConsistencyLevel
AbstractWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints, java.util.Collection<java.net.InetAddress> pendingEndpoints, ConsistencyLevel consistencyLevel, java.lang.Runnable callback, WriteType writeType)
           
DatacenterReadCallback(IResponseResolver resolver, ConsistencyLevel consistencyLevel, IReadCommand command, java.util.List<java.net.InetAddress> endpoints)
           
DatacenterSyncWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints, java.util.Collection<java.net.InetAddress> pendingEndpoints, ConsistencyLevel consistencyLevel, java.lang.String table, java.lang.Runnable callback, WriteType writeType)
           
DatacenterWriteResponseHandler(java.util.Collection<java.net.InetAddress> naturalEndpoints, java.util.Collection<java.net.InetAddress> pendingEndpoints, ConsistencyLevel consistencyLevel, java.lang.String table, java.lang.Runnable callback, WriteType writeType)
           
ReadCallback(IResponseResolver<TMessage,TResolved> resolver, ConsistencyLevel consistencyLevel, IReadCommand command, java.util.List<java.net.InetAddress> endpoints)
          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, java.lang.String table, java.lang.Runnable callback, WriteType writeType)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.thrift
 

Methods in org.apache.cassandra.thrift that return ConsistencyLevel
static ConsistencyLevel ThriftConversion.fromThrift(ConsistencyLevel cl)
           
 

Methods in org.apache.cassandra.thrift with parameters of type ConsistencyLevel
protected  java.util.Map<DecoratedKey,ColumnFamily> CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands, ConsistencyLevel consistency_level)
           
static ConsistencyLevel ThriftConversion.toThrift(ConsistencyLevel cl)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.transport
 

Methods in org.apache.cassandra.transport that return ConsistencyLevel
static ConsistencyLevel CBUtil.readConsistencyLevel(org.jboss.netty.buffer.ChannelBuffer cb)
           
 

Methods in org.apache.cassandra.transport with parameters of type ConsistencyLevel
static org.jboss.netty.buffer.ChannelBuffer CBUtil.consistencyLevelToCB(ConsistencyLevel consistency)
           
 ResultMessage SimpleClient.execute(java.lang.String query, ConsistencyLevel consistency)
           
 ResultMessage SimpleClient.executePrepared(byte[] statementId, java.util.List<java.nio.ByteBuffer> values, ConsistencyLevel consistency)
           
 

Uses of ConsistencyLevel in org.apache.cassandra.transport.messages
 

Fields in org.apache.cassandra.transport.messages declared as ConsistencyLevel
 ConsistencyLevel ExecuteMessage.consistency
           
 ConsistencyLevel QueryMessage.consistency
           
 

Constructors in org.apache.cassandra.transport.messages with parameters of type ConsistencyLevel
ExecuteMessage(byte[] statementId, java.util.List<java.nio.ByteBuffer> values, ConsistencyLevel consistency)
           
ExecuteMessage(MD5Digest statementId, java.util.List<java.nio.ByteBuffer> values, ConsistencyLevel consistency)
           
QueryMessage(java.lang.String query, ConsistencyLevel consistency)
           
 



Copyright © 2012 The Apache Software Foundation