Uses of Class
org.apache.cassandra.exceptions.InvalidRequestException

Packages that use InvalidRequestException
org.apache.cassandra.auth   
org.apache.cassandra.config   
org.apache.cassandra.cql   
org.apache.cassandra.cql3   
org.apache.cassandra.cql3.functions   
org.apache.cassandra.cql3.statements   
org.apache.cassandra.db   
org.apache.cassandra.service   
org.apache.cassandra.thrift   
 

Uses of InvalidRequestException in org.apache.cassandra.auth
 

Methods in org.apache.cassandra.auth that throw InvalidRequestException
 void AllowAllAuthenticator.alter(java.lang.String username, java.util.Map<IAuthenticator.Option,java.lang.Object> options)
           
 void AllowAllAuthenticator.create(java.lang.String username, java.util.Map<IAuthenticator.Option,java.lang.Object> options)
           
 void PasswordAuthenticator.create(java.lang.String username, java.util.Map<IAuthenticator.Option,java.lang.Object> options)
           
 void AllowAllAuthenticator.drop(java.lang.String username)
           
 void AllowAllAuthorizer.grant(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String to)
           
 void LegacyAuthorizer.grant(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String to)
           
 java.util.Set<PermissionDetails> AllowAllAuthorizer.list(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String of)
           
 java.util.Set<PermissionDetails> LegacyAuthorizer.list(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String of)
           
 void AllowAllAuthorizer.revoke(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String from)
           
 void LegacyAuthorizer.revoke(AuthenticatedUser performer, java.util.Set<Permission> permissions, IResource resource, java.lang.String from)
           
 

Uses of InvalidRequestException in org.apache.cassandra.config
 

Methods in org.apache.cassandra.config that throw InvalidRequestException
static CFMetaData CFMetaData.fromThrift(org.apache.cassandra.thrift.CfDef cf_def)
           
 

Uses of InvalidRequestException in org.apache.cassandra.cql
 

Methods in org.apache.cassandra.cql that throw InvalidRequestException
static void AlterTableStatement.applyPropertiesToCFMetadata(CFMetaData cfm, CFPropDefs cfProps)
           
 CFMetaData DropIndexStatement.generateCFMetadataUpdate()
           
 java.nio.ByteBuffer Term.getByteBuffer()
          Returns the typed value, serialized to a ByteBuffer.
 java.nio.ByteBuffer Term.getByteBuffer(AbstractType<?> validator, java.util.List<java.nio.ByteBuffer> variables)
          Returns the typed value, serialized to a ByteBuffer according to a comparator/validator.
 CFMetaData AlterTableStatement.getCFMetaData(java.lang.String keyspace)
           
 CFMetaData CreateColumnFamilyStatement.getCFMetaData(java.lang.String keyspace, java.util.List<java.nio.ByteBuffer> variables)
          Returns a CFMetaData instance based on the parameters parsed from this CREATE statement, or defaults where applicable.
 java.lang.String DropIndexStatement.getColumnFamily()
           
 java.util.Map<Term,Operation> UpdateStatement.getColumns()
           
 java.util.List<IMutation> BatchStatement.getMutations(java.lang.String keyspace, ThriftClientState clientState, java.util.List<java.nio.ByteBuffer> variables)
           
 java.lang.Boolean CFPropDefs.getPropertyBoolean(java.lang.String key, java.lang.Boolean defaultValue)
           
 java.lang.Double CFPropDefs.getPropertyDouble(java.lang.String key, java.lang.Double defaultValue)
           
 java.lang.Integer CFPropDefs.getPropertyInt(java.lang.String key, java.lang.Integer defaultValue)
           
 RowMutation DeleteStatement.mutationForKey(java.nio.ByteBuffer key, java.lang.String keyspace, java.lang.Long timestamp, ThriftClientState clientState, java.util.List<java.nio.ByteBuffer> variables, CFMetaData metadata)
           
static org.apache.cassandra.thrift.CqlPreparedResult QueryProcessor.prepare(java.lang.String queryString, ThriftClientState clientState)
           
abstract  java.util.List<IMutation> AbstractModification.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.util.List<java.nio.ByteBuffer> variables)
          Convert statement into a list of mutations to apply on the server
 java.util.List<IMutation> DeleteStatement.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.util.List<java.nio.ByteBuffer> variables)
           
 java.util.List<IMutation> UpdateStatement.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.util.List<java.nio.ByteBuffer> variables)
          Convert statement into a list of mutations to apply on the server
abstract  java.util.List<IMutation> AbstractModification.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.lang.Long timestamp, java.util.List<java.nio.ByteBuffer> variables)
          Convert statement into a list of mutations to apply on the server
 java.util.List<IMutation> DeleteStatement.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.lang.Long timestamp, java.util.List<java.nio.ByteBuffer> variables)
           
 java.util.List<IMutation> UpdateStatement.prepareRowMutations(java.lang.String keyspace, ThriftClientState clientState, java.lang.Long timestamp, java.util.List<java.nio.ByteBuffer> variables)
          Convert statement into a list of mutations to apply on the server
 void CFPropDefs.validate()
           
 void CreateKeyspaceStatement.validate()
          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.
static void QueryProcessor.validateColumn(CFMetaData metadata, java.nio.ByteBuffer name, java.nio.ByteBuffer value)
           
static void QueryProcessor.validateColumnName(java.nio.ByteBuffer column)
           
static void QueryProcessor.validateKey(java.nio.ByteBuffer key)
           
static void QueryProcessor.validateKeyAlias(CFMetaData cfm, java.lang.String key)
           
 

Uses of InvalidRequestException in org.apache.cassandra.cql3
 

Methods in org.apache.cassandra.cql3 that throw InvalidRequestException
 Constants.Value Constants.Marker.bind(java.util.List<java.nio.ByteBuffer> values)
           
 Lists.Value Lists.Marker.bind(java.util.List<java.nio.ByteBuffer> values)
           
 Maps.Value Maps.Marker.bind(java.util.List<java.nio.ByteBuffer> values)
           
 Sets.Value Sets.Marker.bind(java.util.List<java.nio.ByteBuffer> values)
           
 Term.Terminal Term.bind(java.util.List<java.nio.ByteBuffer> values)
          Bind the values in this term to the values contained in values.
 java.nio.ByteBuffer Constants.Marker.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
           
 java.nio.ByteBuffer Term.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
          A shorter for bind(values).get().
 java.nio.ByteBuffer Term.Terminal.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
           
 java.nio.ByteBuffer Term.NonTerminal.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
           
 void CQLStatement.checkAccess(ClientState state)
          Perform any access verification necessary for the statement.
 void Constants.Setter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Constants.Adder.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Constants.Substracter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Constants.Deleter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.Setter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.SetterByIndex.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.Appender.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.Prepender.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.Discarder.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Lists.DiscarderByIndex.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Maps.Setter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Maps.SetterByKey.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Maps.Putter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Maps.DiscarderByKey.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
abstract  void Operation.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder namePrefix, UpdateParameters params)
          Execute the operation.
 void Sets.Setter.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Sets.Adder.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
 void Sets.Discarder.execute(java.nio.ByteBuffer rowKey, ColumnFamily cf, ColumnNameBuilder prefix, UpdateParameters params)
           
static Lists.Value Lists.Value.fromSerialized(java.nio.ByteBuffer value, ListType type)
           
static Maps.Value Maps.Value.fromSerialized(java.nio.ByteBuffer value, MapType type)
           
static Sets.Value Sets.Value.fromSerialized(java.nio.ByteBuffer value, SetType type)
           
static CQL3Type.Collection CQL3Type.Collection.list(CQL3Type t)
           
static CQL3Type.Collection CQL3Type.Collection.map(CQL3Type t1, CQL3Type t2)
           
 Operation Operation.RawUpdate.prepare(CFDefinition.Name receiver)
          This method validates the operation (i.e.
 Operation Operation.SetValue.prepare(CFDefinition.Name receiver)
           
 Operation Operation.SetElement.prepare(CFDefinition.Name receiver)
           
 Operation Operation.Addition.prepare(CFDefinition.Name receiver)
           
 Operation Operation.Substraction.prepare(CFDefinition.Name receiver)
           
 Operation Operation.Prepend.prepare(CFDefinition.Name receiver)
           
 AbstractMarker AbstractMarker.Raw.prepare(ColumnSpecification receiver)
           
 Constants.Value Constants.Literal.prepare(ColumnSpecification receiver)
           
 Lists.Value Lists.Literal.prepare(ColumnSpecification receiver)
           
 Maps.Value Maps.Literal.prepare(ColumnSpecification receiver)
           
 Operation Operation.RawDeletion.prepare(ColumnSpecification receiver)
          This method validates the operation (i.e.
 Operation Operation.ColumnDeletion.prepare(ColumnSpecification receiver)
           
 Operation Operation.ElementDeletion.prepare(ColumnSpecification receiver)
           
 Term.Terminal Sets.Literal.prepare(ColumnSpecification receiver)
           
 Term Term.Raw.prepare(ColumnSpecification receiver)
          This method validates this RawTerm is valid for provided column specification and "prepare" this RawTerm, returning the resulting prepared Term.
 Term TypeCast.prepare(ColumnSpecification receiver)
           
static CQL3Type.Collection CQL3Type.Collection.set(CQL3Type t)
           
 void UserOptions.validate()
           
static void QueryProcessor.validateColumnName(java.nio.ByteBuffer column)
           
static void QueryProcessor.validateColumnNames(java.lang.Iterable<java.nio.ByteBuffer> columns)
           
static void QueryProcessor.validateFilter(CFMetaData metadata, IDiskAtomFilter filter)
           
static void QueryProcessor.validateKey(java.nio.ByteBuffer key)
           
static void QueryProcessor.validateSliceFilter(CFMetaData metadata, SliceQueryFilter range)
           
 

Uses of InvalidRequestException in org.apache.cassandra.cql3.functions
 

Methods in org.apache.cassandra.cql3.functions that throw InvalidRequestException
 Term.Terminal FunctionCall.bind(java.util.List<java.nio.ByteBuffer> values)
           
 java.nio.ByteBuffer FunctionCall.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
           
 java.nio.ByteBuffer Function.execute(java.util.List<java.nio.ByteBuffer> parameters)
           
 java.nio.ByteBuffer TokenFct.execute(java.util.List<java.nio.ByteBuffer> parameters)
           
static Function Functions.get(java.lang.String name, java.util.List<? extends AssignementTestable> providedArgs, ColumnSpecification receiver)
           
 Term FunctionCall.Raw.prepare(ColumnSpecification receiver)
           
 

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

Methods in org.apache.cassandra.cql3.statements that throw InvalidRequestException
 void CreateIndexStatement.announceMigration()
           
 void DropIndexStatement.announceMigration()
           
 ResultSet Selection.ResultSetBuilder.build()
           
 void AlterKeyspaceStatement.checkAccess(ClientState state)
           
 void AlterTableStatement.checkAccess(ClientState state)
           
 void BatchStatement.checkAccess(ClientState state)
           
 void CreateColumnFamilyStatement.checkAccess(ClientState state)
           
 void CreateIndexStatement.checkAccess(ClientState state)
           
 void CreateKeyspaceStatement.checkAccess(ClientState state)
           
 void DropColumnFamilyStatement.checkAccess(ClientState state)
           
 void DropIndexStatement.checkAccess(ClientState state)
           
 void DropKeyspaceStatement.checkAccess(ClientState state)
           
 void ModificationStatement.checkAccess(ClientState state)
           
 void SelectStatement.checkAccess(ClientState state)
           
 void TruncateStatement.checkAccess(ClientState state)
           
 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)
           
static Selection Selection.fromSelectors(CFDefinition cfDef, java.util.List<RawSelector> rawSelectors)
           
protected abstract  java.util.List<java.nio.ByteBuffer> Selection.handleRow(Selection.ResultSetBuilder rs)
           
static DataResource AuthorizationStatement.maybeCorrectResource(DataResource resource, ClientState state)
           
 RowMutation DeleteStatement.mutationForKey(CFDefinition cfDef, java.nio.ByteBuffer key, ColumnNameBuilder builder, boolean isRange, UpdateParameters params)
           
 void Selection.ResultSetBuilder.newRow()
           
 ParsedStatement.Prepared BatchStatement.prepare()
           
 ParsedStatement.Prepared DeleteStatement.prepare()
           
 ParsedStatement.Prepared SelectStatement.RawStatement.prepare()
           
 ParsedStatement.Prepared TruncateStatement.prepare()
           
 ParsedStatement.Prepared UpdateStatement.prepare()
           
 ParsedStatement.Prepared UseStatement.prepare()
           
 ParsedStatement.Prepared BatchStatement.prepare(ColumnSpecification[] boundNames)
           
 ParsedStatement.Prepared DeleteStatement.prepare(ColumnSpecification[] boundNames)
           
abstract  ParsedStatement.Prepared ModificationStatement.prepare(ColumnSpecification[] boundNames)
           
 ParsedStatement.Prepared UpdateStatement.prepare(ColumnSpecification[] boundNames)
           
 void BatchStatement.prepareKeyspace(ClientState state)
           
 void CFStatement.prepareKeyspace(ClientState state)
           
 void SchemaAlteringStatement.prepareKeyspace(ClientState state)
           
 ResultSet SelectStatement.process(java.util.List<Row> rows)
           
 void BatchStatement.validate(ClientState state)
           
 void ModificationStatement.validate(ClientState state)
           
 void SelectStatement.validate(ClientState state)
           
 void TruncateStatement.validate(ClientState state)
           
 void UseStatement.validate(ClientState state)
           
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 InvalidRequestException in org.apache.cassandra.db
 

Subclasses of InvalidRequestException in org.apache.cassandra.db
 class KeyspaceNotDefinedException
           
 

Methods in org.apache.cassandra.db that throw InvalidRequestException
 void ConsistencyLevel.validateCounterForWrite(CFMetaData metadata)
           
 void ConsistencyLevel.validateForRead(java.lang.String table)
           
 void ConsistencyLevel.validateForWrite(java.lang.String table)
           
 

Uses of InvalidRequestException in org.apache.cassandra.service
 

Methods in org.apache.cassandra.service that throw InvalidRequestException
 java.util.List<org.apache.cassandra.thrift.TokenRange> StorageService.describeRing(java.lang.String keyspace)
          The TokenRange for a given keyspace.
 java.lang.String ClientState.getKeyspace()
           
 void ClientState.hasAllKeyspacesAccess(Permission perm)
           
 void ClientState.hasColumnFamilyAccess(java.lang.String keyspace, java.lang.String columnFamily, Permission perm)
           
 void ClientState.hasKeyspaceAccess(java.lang.String keyspace, Permission perm)
           
 void ClientState.setCQLVersion(java.lang.String str)
           
 void ClientState.setKeyspace(java.lang.String ks)
           
 

Uses of InvalidRequestException in org.apache.cassandra.thrift
 

Methods in org.apache.cassandra.thrift with parameters of type InvalidRequestException
static org.apache.cassandra.thrift.InvalidRequestException ThriftConversion.toThrift(InvalidRequestException e)
           
 

Methods in org.apache.cassandra.thrift that throw InvalidRequestException
protected  java.util.Map<DecoratedKey,ColumnFamily> CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands, ConsistencyLevel consistency_level)
           
static void ThriftValidation.validateColumnData(CFMetaData metadata, org.apache.cassandra.thrift.Column column, boolean isSubColumn)
          Validates the data part of the column (everything in the Column object but the name, which is assumed to be valid)
static CFMetaData ThriftValidation.validateColumnFamily(java.lang.String tablename, java.lang.String cfName)
           
static CFMetaData ThriftValidation.validateColumnFamily(java.lang.String tablename, java.lang.String cfName, boolean isCommutativeOp)
           
static void ThriftValidation.validateColumnNames(CFMetaData metadata, org.apache.cassandra.thrift.ColumnParent column_parent, java.lang.Iterable<java.nio.ByteBuffer> column_names)
           
static void ThriftValidation.validateColumnOrSuperColumn(CFMetaData metadata, org.apache.cassandra.thrift.ColumnOrSuperColumn cosc)
           
static void ThriftValidation.validateColumnParent(CFMetaData metadata, org.apache.cassandra.thrift.ColumnParent column_parent)
           
static void ThriftValidation.validateColumnPath(CFMetaData metadata, org.apache.cassandra.thrift.ColumnPath column_path)
          validates all parts of the path to the column, including the column name
static void ThriftValidation.validateDeletion(CFMetaData metadata, org.apache.cassandra.thrift.Deletion del)
           
static boolean ThriftValidation.validateFilterClauses(CFMetaData metadata, java.util.List<org.apache.cassandra.thrift.IndexExpression> index_clause)
           
static void ThriftValidation.validateIndexClauses(CFMetaData metadata, org.apache.cassandra.thrift.IndexClause index_clause)
           
static void ThriftValidation.validateKey(CFMetaData metadata, java.nio.ByteBuffer key)
           
static void ThriftValidation.validateKeyRange(CFMetaData metadata, java.nio.ByteBuffer superColumn, org.apache.cassandra.thrift.KeyRange range)
           
static void ThriftValidation.validateKeyspaceNotSystem(java.lang.String modifiedKeyspace)
           
static void ThriftValidation.validateKeyspaceNotYetExisting(java.lang.String newKsName)
           
static void ThriftValidation.validateMutation(CFMetaData metadata, org.apache.cassandra.thrift.Mutation mut)
           
static void ThriftValidation.validatePredicate(CFMetaData metadata, org.apache.cassandra.thrift.ColumnParent column_parent, org.apache.cassandra.thrift.SlicePredicate predicate)
           
static void ThriftValidation.validateRange(CFMetaData metadata, org.apache.cassandra.thrift.ColumnParent column_parent, org.apache.cassandra.thrift.SliceRange range)
           
static void ThriftValidation.validateSlicePredicate(CFMetaData metadata, java.nio.ByteBuffer scName, org.apache.cassandra.thrift.SlicePredicate predicate)
           
 



Copyright © 2013 The Apache Software Foundation