Uses of Class
org.apache.cassandra.exceptions.InvalidRequestException
-
-
Uses of InvalidRequestException in org.apache.cassandra.cql3
Methods in org.apache.cassandra.cql3 that throw InvalidRequestException Modifier and Type Method Description Cell<?>
UpdateParameters. addCell(ColumnMetadata column, java.nio.ByteBuffer value)
Cell<?>
UpdateParameters. addCell(ColumnMetadata column, CellPath path, java.nio.ByteBuffer value)
void
UpdateParameters. addCounter(ColumnMetadata column, long increment)
void
UpdateParameters. addTombstone(ColumnMetadata column)
void
UpdateParameters. addTombstone(ColumnMetadata column, CellPath path)
Constants.Value
Constants.Marker. bind(QueryOptions options)
Term.Terminal
Lists.DelayedValue. bind(QueryOptions options)
Term.Terminal
Lists.Marker. bind(QueryOptions options)
Term.Terminal
Maps.DelayedValue. bind(QueryOptions options)
Term.Terminal
Maps.Marker. bind(QueryOptions options)
Term.Terminal
Sets.DelayedValue. bind(QueryOptions options)
Term.Terminal
Sets.Marker. bind(QueryOptions options)
Term.Terminal
Term. bind(QueryOptions options)
Bind the values in this term to the values contained invalues
.Tuples.Value
Tuples.DelayedValue. bind(QueryOptions options)
Tuples.InValue
Tuples.InMarker. bind(QueryOptions options)
Tuples.Value
Tuples.Marker. bind(QueryOptions options)
UserTypes.Value
UserTypes.DelayedValue. bind(QueryOptions options)
Term.Terminal
UserTypes.Marker. bind(QueryOptions options)
Term.Terminal
Vectors.DelayedValue. bind(QueryOptions options)
java.nio.ByteBuffer
Constants.Marker. bindAndGet(QueryOptions options)
java.nio.ByteBuffer
Term. bindAndGet(QueryOptions options)
A shorter for bind(values).get().java.nio.ByteBuffer
Term.NonTerminal. bindAndGet(QueryOptions options)
java.nio.ByteBuffer
Term.Terminal. bindAndGet(QueryOptions options)
java.nio.ByteBuffer
Tuples.DelayedValue. bindAndGet(QueryOptions options)
java.nio.ByteBuffer
UserTypes.DelayedValue. bindAndGet(QueryOptions options)
void
Constants.Adder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Deleter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Substracter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Appender. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Discarder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.DiscarderByIndex. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Prepender. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.SetterByIndex. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.DiscarderByKey. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.Putter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.SetterByKey. execute(DecoratedKey partitionKey, UpdateParameters params)
abstract void
Operation. execute(DecoratedKey partitionKey, UpdateParameters params)
Execute the operation.void
Sets.Adder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Sets.Discarder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Sets.ElementDiscarder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Sets.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.DeleterByField. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.SetterByField. execute(DecoratedKey partitionKey, UpdateParameters params)
static <T> Lists.Value
Lists.Value. fromSerialized(java.nio.ByteBuffer value, ListType<T> type)
static <K,V>
Maps.ValueMaps.Value. fromSerialized(java.nio.ByteBuffer value, MapType<K,V> type)
static <T> Sets.Value
Sets.Value. fromSerialized(java.nio.ByteBuffer value, SetType<T> type)
static <T> Tuples.InValue
Tuples.InValue. fromSerialized(java.nio.ByteBuffer value, ListType<T> type)
abstract java.nio.ByteBuffer
Term.Terminal. get(ProtocolVersion version)
Term
QueryOptions. getJsonColumnValue(int bindIndex, ColumnIdentifier columnName, java.util.Collection<ColumnMetadata> expectedReceivers)
Returns the term corresponding to columncolumnName
in the JSON value of bind indexbindIndex
.static ResultMessage.Prepared
QueryProcessor. getStoredPreparedStatement(java.lang.String queryString, java.lang.String clientKeyspace)
long
Attributes. getTimestamp(long now, QueryOptions options)
int
Attributes. getTimeToLive(QueryOptions options, TableMetadata metadata)
protected Restriction
SingleColumnRelation. newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey)
protected Restriction
SingleColumnRelation. newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames)
<V> void
UpdateParameters. newRow(Clustering<V> clustering)
Lists.Marker
AbstractMarker.INRaw. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term.NonTerminal
AbstractMarker.MultiColumnRaw. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term.NonTerminal
AbstractMarker.Raw. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term
ArrayLiteral. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Attributes
Attributes.Raw. prepare(java.lang.String ksName, java.lang.String cfName)
Constants.Value
Constants.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
abstract CQL3Type
CQL3Type.Raw. prepare(java.lang.String keyspace, Types udts)
Term
Lists.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term
Maps.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Operation
Operation.Addition. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.ColumnDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.ElementDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.FieldDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.Prepend. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.RawDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
This method validates the operation (i.e.Operation
Operation.RawUpdate. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
This method validates the operation (i.e.Operation
Operation.SetElement. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.SetField. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.SetValue. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.Substraction. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Term
Sets.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
abstract Term
Term.MultiColumnRaw. prepare(java.lang.String keyspace, java.util.List<? extends ColumnSpecification> receiver)
abstract Term
Term.Raw. prepare(java.lang.String keyspace, ColumnSpecification receiver)
This method validates this RawTerm is valid for provided column specification and "prepare" this RawTerm, returning the resulting prepared Term.AbstractMarker
Tuples.INRaw. prepare(java.lang.String keyspace, java.util.List<? extends ColumnSpecification> receivers)
Term
Tuples.Literal. prepare(java.lang.String keyspace, java.util.List<? extends ColumnSpecification> receivers)
Term
Tuples.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
AbstractMarker
Tuples.Raw. prepare(java.lang.String keyspace, java.util.List<? extends ColumnSpecification> receivers)
Term
TypeCast. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term
UserTypes.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
Term
Vectors.Literal. prepare(java.lang.String keyspace, ColumnSpecification receiver)
CQL3Type
CQL3Type.Raw. prepareInternal(java.lang.String keyspace, Types udts)
protected java.util.List<ColumnMetadata>
MultiColumnRelation. receivers(TableMetadata table)
static ResultMessage.Prepared
QueryProcessor. storePreparedStatement(java.lang.String queryString, java.lang.String keyspace, QueryHandler.Prepared prepared)
protected Term
MultiColumnRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers, Term.Raw raw, java.lang.String keyspace, VariableSpecifications boundNames)
protected Term
SingleColumnRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers, Term.Raw raw, java.lang.String keyspace, VariableSpecifications boundNames)
protected Term
TokenRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers, Term.Raw raw, java.lang.String keyspace, VariableSpecifications boundNames)
static void
QueryProcessor. validateKey(java.nio.ByteBuffer key)
Constructors in org.apache.cassandra.cql3 that throw InvalidRequestException Constructor Description UpdateParameters(TableMetadata metadata, RegularAndStaticColumns updatedColumns, ClientState clientState, QueryOptions options, long timestamp, long nowInSec, int ttl, java.util.Map<DecoratedKey,Partition> prefetchedRows)
-
Uses of InvalidRequestException in org.apache.cassandra.cql3.functions
Methods in org.apache.cassandra.cql3.functions that return InvalidRequestException Modifier and Type Method Description InvalidRequestException
FunctionFactory. invalidNumberOfArgumentsException()
Methods in org.apache.cassandra.cql3.functions with parameters of type InvalidRequestException Modifier and Type Method Description static UDFunction
UDFunction. createBrokenFunction(FunctionName name, java.util.List<ColumnIdentifier> argNames, java.util.List<AbstractType<?>> argTypes, AbstractType<?> returnType, boolean calledOnNullInput, java.lang.String language, java.lang.String body, InvalidRequestException reason)
It can happen that a function has been declared (is listed in the scheam) but cannot be loaded (maybe only on some nodes).Methods in org.apache.cassandra.cql3.functions that throw InvalidRequestException Modifier and Type Method Description void
AggregateFunction.Aggregate. addInput(Arguments arguments)
Adds the specified input to this aggregate.Term.Terminal
FunctionCall. bind(QueryOptions options)
java.nio.ByteBuffer
FunctionCall. bindAndGet(QueryOptions options)
java.nio.ByteBuffer
AggregateFunction.Aggregate. compute(ProtocolVersion protocolVersion)
Computes and returns the aggregate current value.java.nio.ByteBuffer
ScalarFunction. execute(Arguments arguments)
Applies this function to the specified arguments.java.nio.ByteBuffer
ToJsonFct. execute(Arguments arguments)
java.nio.ByteBuffer
TokenFct. execute(Arguments arguments)
static Function
FunctionResolver. get(java.lang.String keyspace, FunctionName name, java.util.List<? extends AssignmentTestable> providedArgs, java.lang.String receiverKeyspace, java.lang.String receiverTable, AbstractType<?> receiverType)
static Function
FunctionResolver. get(java.lang.String keyspace, FunctionName name, java.util.List<? extends AssignmentTestable> providedArgs, java.lang.String receiverKeyspace, java.lang.String receiverTable, AbstractType<?> receiverType, UserFunctions functions)
static ToJsonFct
ToJsonFct. getInstance(java.lang.String name, java.util.List<AbstractType<?>> argTypes)
AggregateFunction.Aggregate
AggregateFunction. newAggregate()
Creates a newAggregate
instance.AggregateFunction.Aggregate
UDAggregate. newAggregate()
Term
FunctionCall.Raw. prepare(java.lang.String keyspace, ColumnSpecification receiver)
-
Uses of InvalidRequestException in org.apache.cassandra.cql3.functions.masking
Methods in org.apache.cassandra.cql3.functions.masking that throw InvalidRequestException Modifier and Type Method Description java.nio.ByteBuffer
DefaultMaskingFunction. execute(Arguments arguments)
java.nio.ByteBuffer
HashMaskingFunction. execute(Arguments arguments)
java.nio.ByteBuffer
NullMaskingFunction. execute(Arguments arguments)
java.nio.ByteBuffer
PartialMaskingFunction. execute(Arguments arguments)
java.nio.ByteBuffer
ReplaceMaskingFunction. execute(Arguments arguments)
-
Uses of InvalidRequestException in org.apache.cassandra.cql3.restrictions
Methods in org.apache.cassandra.cql3.restrictions that throw InvalidRequestException Modifier and Type Method Description java.util.List<java.nio.ByteBuffer>
TokenRestriction.EQRestriction. bounds(Bound b, QueryOptions options)
java.util.List<java.nio.ByteBuffer>
TokenRestriction.SliceRestriction. bounds(Bound b, QueryOptions options)
protected abstract org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions
TokenRestriction. doMergeWith(TokenRestriction otherRestriction)
Merges this restriction with the specifiedTokenRestriction
.protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions
TokenRestriction.EQRestriction. doMergeWith(TokenRestriction otherRestriction)
protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions
TokenRestriction.SliceRestriction. doMergeWith(TokenRestriction otherRestriction)
org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions
TokenRestriction. mergeWith(Restriction otherRestriction)
java.util.List<java.nio.ByteBuffer>
TokenRestriction.EQRestriction. values(QueryOptions options, ClientState state)
java.util.List<java.nio.ByteBuffer>
TokenRestriction.SliceRestriction. values(QueryOptions options, ClientState state)
-
Uses of InvalidRequestException in org.apache.cassandra.cql3.selection
Methods in org.apache.cassandra.cql3.selection that throw InvalidRequestException Modifier and Type Method Description void
SimpleSelector. addInput(Selector.InputRow input)
abstract java.nio.ByteBuffer
Selector. getOutput(ProtocolVersion protocolVersion)
Returns the selector output.java.nio.ByteBuffer
VectorSelector. getOutput(ProtocolVersion protocolVersion)
Selector.Factory
Selectable.WithTerm. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
-
Uses of InvalidRequestException in org.apache.cassandra.cql3.statements
Methods in org.apache.cassandra.cql3.statements that return InvalidRequestException Modifier and Type Method Description static InvalidRequestException
RequestValidations. invalidRequest(java.lang.String message)
Returns anInvalidRequestException
with the specified message.static InvalidRequestException
RequestValidations. invalidRequest(java.lang.String messageTemplate, java.lang.Object... messageArgs)
Returns anInvalidRequestException
with the specified message.Methods in org.apache.cassandra.cql3.statements that throw InvalidRequestException Modifier and Type Method Description void
CQL3CasRequest. addConditions(Clustering<?> clustering, java.util.Collection<ColumnCondition> conds, QueryOptions options)
void
ModificationStatement. addConditions(Clustering<?> clustering, CQL3CasRequest request, QueryOptions options)
void
CQL3CasRequest. addExist(Clustering<?> clustering)
void
CQL3CasRequest. addNotExist(Clustering<?> clustering)
void
DeleteStatement. addUpdateForKey(PartitionUpdate.Builder updateBuilder, Clustering<?> clustering, UpdateParameters params)
boolean
CQL3CasRequest. appliesTo(FilteredPartition current)
Checks whether the conditions represented by this object applies provided the current state of the partition on which those conditions are.void
BatchStatement. authorize(ClientState state)
void
ListRolesStatement. authorize(ClientState state)
void
ModificationStatement. authorize(ClientState state)
void
SelectStatement. authorize(ClientState state)
void
TruncateStatement. authorize(ClientState state)
java.util.List<java.nio.ByteBuffer>
ModificationStatement. buildPartitionKeyNames(QueryOptions options, ClientState state)
static void
RequestValidations. checkBindValueSet(java.nio.ByteBuffer b, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified bind marker value is set to a meaningful value.static void
RequestValidations. checkContainsNoDuplicates(java.util.List<?> list, java.lang.String message)
Checks that the specified list does not contains duplicates.static <E> void
RequestValidations. checkContainsOnly(java.util.List<E> list, java.util.List<E> expectedElements, java.lang.String message)
Checks that the specified list contains only the specified elements.static void
RequestValidations. checkFalse(boolean expression, java.lang.String message)
Checks that the specified expression isfalse
.static void
RequestValidations. checkFalse(boolean expression, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified expression isfalse
.static void
RequestValidations. checkFalse(boolean expression, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2)
Checks that the specified expression isfalse
.static void
RequestValidations. checkFalse(boolean expression, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2, java.lang.Object arg3)
Checks that the specified expression isfalse
.static <T extends java.util.Collection<E>,E>
TRequestValidations. checkNotEmpty(T collection, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified collections is NOTempty
.static <T extends java.util.Collection<E>,E>
TRequestValidations. checkNotEmpty(T collection, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2)
Checks that the specified collections is NOTempty
.static <T> T
RequestValidations. checkNotNull(T object, java.lang.String message)
Checks that the specified object is NOTnull
.static <T> T
RequestValidations. checkNotNull(T object, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified object is NOTnull
.static <T> T
RequestValidations. checkNotNull(T object, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2)
Checks that the specified object is NOTnull
.static void
RequestValidations. checkNull(java.lang.Object object, java.lang.String message)
Checks that the specified object isnull
.static void
RequestValidations. checkNull(java.lang.Object object, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified object isnull
.static void
RequestValidations. checkTrue(boolean expression, java.lang.String message)
Checks that the specified expression istrue
.static void
RequestValidations. checkTrue(boolean expression, java.lang.String messageTemplate, java.lang.Object messageArg)
Checks that the specified expression istrue
.static void
RequestValidations. checkTrue(boolean expression, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2)
Checks that the specified expression istrue
.static void
RequestValidations. checkTrue(boolean expression, java.lang.String messageTemplate, java.lang.Object arg1, java.lang.Object arg2, java.lang.Object arg3)
Checks that the specified expression istrue
.java.util.NavigableSet<Clustering<?>>
ModificationStatement. createClustering(QueryOptions options, ClientState state)
ResultMessage
TruncateStatement. execute(QueryState state, QueryOptions options, Dispatcher.RequestTime requestTime)
ResultMessage
UseStatement. execute(QueryState state, QueryOptions options, Dispatcher.RequestTime requestTime)
ResultMessage
UseStatement. executeLocally(QueryState state, QueryOptions options)
RowFilter
SelectStatement. getRowFilter(QueryOptions options, ClientState state)
May be used by custom QueryHandler implementationslong
ModificationStatement. getTimestamp(long now, QueryOptions options)
int
ModificationStatement. getTimeToLive(QueryOptions options)
Slices
SelectStatement. makeSlices(QueryOptions options)
PartitionUpdate
CQL3CasRequest. makeUpdates(FilteredPartition current, ClientState clientState, Ballot ballot)
static IResource
AuthorizationStatement. maybeCorrectResource(IResource resource, ClientState state)
SelectStatement
SelectStatement.RawStatement. prepare(ClientState state, boolean forView)
ResultSet
SelectStatement. process(PartitionIterator partitions, long nowInSec, boolean unmask, ClientState state)
void
SelectStatement. processPartition(RowIterator partition, QueryOptions options, ResultSetBuilder result, long nowInSec)
void
BatchStatement.Parsed. setKeyspace(ClientState state)
void
BatchStatement. validate()
void
BatchStatement. validate(ClientState state)
void
ListRolesStatement. validate(ClientState state)
void
ModificationStatement. validate(ClientState state)
void
SelectStatement. validate(ClientState state)
void
TruncateStatement. validate(ClientState state)
void
UseStatement. validate(ClientState state)
-
Uses of InvalidRequestException in org.apache.cassandra.db
Subclasses of InvalidRequestException in org.apache.cassandra.db Modifier and Type Class Description class
KeyspaceNotDefinedException
class
MutationExceededMaxSizeException
Methods in org.apache.cassandra.db that throw InvalidRequestException Modifier and Type Method Description static void
ExpirationDateOverflowHandling. maybeApplyExpirationDateOverflowPolicy(TableMetadata metadata, int ttl, boolean isDefaultTTL)
void
ConsistencyLevel. validateCounterForWrite(TableMetadata metadata)
void
ConsistencyLevel. validateForCas()
void
ConsistencyLevel. validateForCasCommit(AbstractReplicationStrategy replicationStrategy)
void
ConsistencyLevel. validateForRead()
void
ConsistencyLevel. validateForWrite()
-
Uses of InvalidRequestException in org.apache.cassandra.db.guardrails
Subclasses of InvalidRequestException in org.apache.cassandra.db.guardrails Modifier and Type Class Description class
GuardrailViolatedException
-
Uses of InvalidRequestException in org.apache.cassandra.index
Methods in org.apache.cassandra.index that throw InvalidRequestException Modifier and Type Method Description default void
Index.QueryPlan. validate(ReadCommand command)
Used to validate the various parameters of a suppliedReadCommand
against the indexes in this plan.void
Index. validate(PartitionUpdate update, ClientState state)
Called at write time to ensure that values present in the update are valid according to the rules of all registered indexes which will process it.default void
Index. validate(ReadCommand command)
Used to validate the various parameters of a supplied ReadCommand, this is called prior to execution.void
SecondaryIndexManager. validate(PartitionUpdate update, ClientState state)
Called at write time to ensure that values present in the update are valid according to the rules of all registered indexes which will process it. -
Uses of InvalidRequestException in org.apache.cassandra.index.internal
Methods in org.apache.cassandra.index.internal that throw InvalidRequestException Modifier and Type Method Description void
CassandraIndex. validate(PartitionUpdate update, ClientState state)
void
CassandraIndex. validate(ReadCommand command)
-
Uses of InvalidRequestException in org.apache.cassandra.index.sai
Methods in org.apache.cassandra.index.sai that throw InvalidRequestException Modifier and Type Method Description Index.Searcher
StorageAttachedIndex. searcherFor(ReadCommand command)
void
StorageAttachedIndex. validate(PartitionUpdate update, ClientState state)
void
StorageAttachedIndex. validate(ReadCommand command)
-
Uses of InvalidRequestException in org.apache.cassandra.index.sasi
Methods in org.apache.cassandra.index.sasi that throw InvalidRequestException Modifier and Type Method Description Index.Searcher
SASIIndex. searcherFor(ReadCommand command)
void
SASIIndex. validate(PartitionUpdate update, ClientState state)
-
Uses of InvalidRequestException in org.apache.cassandra.io.sstable
Methods in org.apache.cassandra.io.sstable that throw InvalidRequestException Modifier and Type Method Description CQLSSTableWriter
CQLSSTableWriter. addRow(java.lang.Object... values)
Adds a new row to the writer.CQLSSTableWriter
CQLSSTableWriter. addRow(java.util.List<java.lang.Object> values)
Adds a new row to the writer.CQLSSTableWriter
CQLSSTableWriter. addRow(java.util.Map<java.lang.String,java.lang.Object> values)
Adds a new row to the writer.CQLSSTableWriter
CQLSSTableWriter. rawAddRow(java.nio.ByteBuffer... values)
Adds a new row to the writer given already serialized values.CQLSSTableWriter
CQLSSTableWriter. rawAddRow(java.util.List<java.nio.ByteBuffer> values)
Adds a new row to the writer given already serialized values.CQLSSTableWriter
CQLSSTableWriter. rawAddRow(java.util.Map<java.lang.String,java.nio.ByteBuffer> values)
Adds a new row to the writer given already serialized values. -
Uses of InvalidRequestException in org.apache.cassandra.schema
Methods in org.apache.cassandra.schema that throw InvalidRequestException Modifier and Type Method Description Selector.Factory
ColumnMetadata. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
-
Uses of InvalidRequestException in org.apache.cassandra.service
Methods in org.apache.cassandra.service that throw InvalidRequestException Modifier and Type Method Description boolean
CASRequest. appliesTo(FilteredPartition current)
Returns whether the provided CF, that represents the values fetched using the readFilter(), match the CAS conditions this object stands for.static RowIterator
StorageProxy. cas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState clientState, long nowInSeconds, Dispatcher.RequestTime requestTime)
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions.java.util.List<TokenRange>
StorageService. describeLocalRing(java.lang.String keyspace)
The same asdescribeRing(String)
but considers only the part of the ring formed by nodes in the local DC.java.util.List<TokenRange>
StorageService. describeRing(java.lang.String keyspace)
The TokenRange for a given keyspace.java.lang.String
ClientState. getKeyspace()
static RowIterator
StorageProxy. legacyCas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState clientState, long nowInSeconds, Dispatcher.RequestTime requestTime)
PartitionUpdate
CASRequest. makeUpdates(FilteredPartition current, ClientState clientState, Ballot ballot)
The updates to perform of a CAS success.static void
StorageProxy. mutateWithTriggers(java.util.List<? extends IMutation> mutations, ConsistencyLevel consistencyLevel, boolean mutateAtomically, Dispatcher.RequestTime requestTime)
static PartitionIterator
StorageProxy. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
Performs the actual reading of a row out of the StorageService, fetching a specific set of column names from a given column family.static RowIterator
StorageProxy. readOne(SinglePartitionReadCommand command, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
-
Uses of InvalidRequestException in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos that throw InvalidRequestException Modifier and Type Method Description static RowIterator
Paxos. cas(DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForConsensus, ConsistencyLevel consistencyForCommit, ClientState clientState)
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions.static RowIterator
Paxos. cas(DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForConsensus, ConsistencyLevel consistencyForCommit, ClientState clientState, long proposeDeadline, long commitDeadline)
static PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus, long deadline)
static PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus, Dispatcher.RequestTime requestTime)
-
Uses of InvalidRequestException in org.apache.cassandra.service.paxos.uncommitted
Methods in org.apache.cassandra.service.paxos.uncommitted that throw InvalidRequestException Modifier and Type Method Description void
PaxosUncommittedIndex. validate(PartitionUpdate update, ClientState state)
-
Uses of InvalidRequestException in org.apache.cassandra.triggers
Methods in org.apache.cassandra.triggers that throw InvalidRequestException Modifier and Type Method Description java.util.Collection<Mutation>
TriggerExecutor. execute(java.util.Collection<? extends IMutation> mutations)
Takes a collection of mutations and possibly augments it by adding extra mutations generated by configured triggers.PartitionUpdate
TriggerExecutor. execute(PartitionUpdate updates)
Augment a partition update by executing triggers to generate an intermediate set of mutations, then merging the update from each mutation with those supplied.
-