All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.cassandra.cql3.Relation Maven / Gradle / Ivy

Go to download

The Apache Cassandra Project develops a highly scalable second-generation distributed database, bringing together Dynamo's fully distributed design and Bigtable's ColumnFamily-based data model.

The newest version!
/*
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package org.apache.cassandra.cql3;

import java.util.ArrayList;
import java.util.List;

import org.apache.cassandra.schema.TableMetadata;
import org.apache.cassandra.cql3.restrictions.Restriction;
import org.apache.cassandra.cql3.statements.Bound;
import org.apache.cassandra.exceptions.InvalidRequestException;

import static org.apache.cassandra.cql3.statements.RequestValidations.invalidRequest;

public abstract class Relation
{
    protected Operator relationType;

    public Operator operator()
    {
        return relationType;
    }

    /**
     * Returns the raw value for this relation, or null if this is an IN relation.
     */
    public abstract Term.Raw getValue();

    /**
     * Returns the list of raw IN values for this relation, or null if this is not an IN relation.
     */
    public abstract List getInValues();

    /**
     * Checks if this relation apply to multiple columns.
     *
     * @return true if this relation apply to multiple columns, false otherwise.
     */
    public boolean isMultiColumn()
    {
        return false;
    }

    /**
     * Checks if this relation is a token relation (e.g. 
token(a) = token(1)
). * * @return true if this relation is a token relation, false otherwise. */ public boolean onToken() { return false; } /** * Checks if the operator of this relation is a CONTAINS. * @return true if the operator of this relation is a CONTAINS, false * otherwise. */ public final boolean isContains() { return relationType == Operator.CONTAINS; } /** * Checks if the operator of this relation is a CONTAINS_KEY. * @return true if the operator of this relation is a CONTAINS_KEY, false * otherwise. */ public final boolean isContainsKey() { return relationType == Operator.CONTAINS_KEY; } /** * Checks if the operator of this relation is a IN. * @return true if the operator of this relation is a IN, false * otherwise. */ public final boolean isIN() { return relationType == Operator.IN; } /** * Checks if the operator of this relation is a EQ. * @return true if the operator of this relation is a EQ, false * otherwise. */ public final boolean isEQ() { return relationType == Operator.EQ; } public final boolean isLIKE() { return relationType == Operator.LIKE_PREFIX || relationType == Operator.LIKE_SUFFIX || relationType == Operator.LIKE_CONTAINS || relationType == Operator.LIKE_MATCHES || relationType == Operator.LIKE; } /** * Checks if the operator of this relation is a Slice (GT, GTE, LTE, LT). * * @return true if the operator of this relation is a Slice, false otherwise. */ public final boolean isSlice() { return relationType == Operator.GT || relationType == Operator.GTE || relationType == Operator.LTE || relationType == Operator.LT; } /** * Converts this Relation into a Restriction. * * @param table the Column Family meta data * @param boundNames the variables specification where to collect the bind variables * @return the Restriction corresponding to this Relation * @throws InvalidRequestException if this Relation is not valid */ public final Restriction toRestriction(TableMetadata table, VariableSpecifications boundNames) { switch (relationType) { case EQ: return newEQRestriction(table, boundNames); case LT: return newSliceRestriction(table, boundNames, Bound.END, false); case LTE: return newSliceRestriction(table, boundNames, Bound.END, true); case GTE: return newSliceRestriction(table, boundNames, Bound.START, true); case GT: return newSliceRestriction(table, boundNames, Bound.START, false); case IN: return newINRestriction(table, boundNames); case CONTAINS: return newContainsRestriction(table, boundNames, false); case CONTAINS_KEY: return newContainsRestriction(table, boundNames, true); case IS_NOT: return newIsNotRestriction(table, boundNames); case LIKE_PREFIX: case LIKE_SUFFIX: case LIKE_CONTAINS: case LIKE_MATCHES: case LIKE: return newLikeRestriction(table, boundNames, relationType); case ANN: throw invalidRequest("ANN is only supported in ORDER BY"); default: throw invalidRequest("Unsupported \"!=\" relation: %s", this); } } /** * Creates a new EQ restriction instance. * * @param table the table meta data * @param boundNames the variables specification where to collect the bind variables * @return a new EQ restriction instance. * @throws InvalidRequestException if the relation cannot be converted into an EQ restriction. */ protected abstract Restriction newEQRestriction(TableMetadata table, VariableSpecifications boundNames); /** * Creates a new IN restriction instance. * * @param table the table meta data * @param boundNames the variables specification where to collect the bind variables * @return a new IN restriction instance * @throws InvalidRequestException if the relation cannot be converted into an IN restriction. */ protected abstract Restriction newINRestriction(TableMetadata table, VariableSpecifications boundNames); /** * Creates a new Slice restriction instance. * * @param table the table meta data * @param boundNames the variables specification where to collect the bind variables * @param bound the slice bound * @param inclusive true if the bound is included. * @return a new slice restriction instance * @throws InvalidRequestException if the Relation is not valid */ protected abstract Restriction newSliceRestriction(TableMetadata table, VariableSpecifications boundNames, Bound bound, boolean inclusive); /** * Creates a new Contains restriction instance. * * @param table the table meta data * @param boundNames the variables specification where to collect the bind variables * @param isKey true if the restriction to create is a CONTAINS KEY * @return a new Contains Restriction instance * @throws InvalidRequestException if the Relation is not valid */ protected abstract Restriction newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey); protected abstract Restriction newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames); protected abstract Restriction newLikeRestriction(TableMetadata table, VariableSpecifications boundNames, Operator operator); /** * Converts the specified Raw into a Term. * @param receivers the columns to which the values must be associated at * @param raw the raw term to convert * @param keyspace the keyspace name * @param boundNames the variables specification where to collect the bind variables * * @return the Term corresponding to the specified Raw * @throws InvalidRequestException if the Raw term is not valid */ protected abstract Term toTerm(List receivers, Term.Raw raw, String keyspace, VariableSpecifications boundNames); /** * Converts the specified Raw terms into a Terms. * @param receivers the columns to which the values must be associated at * @param raws the raw terms to convert * @param keyspace the keyspace name * @param boundNames the variables specification where to collect the bind variables * * @return the Terms corresponding to the specified Raw terms * @throws InvalidRequestException if the Raw terms are not valid */ protected final List toTerms(List receivers, List raws, String keyspace, VariableSpecifications boundNames) { if (raws == null) return null; List terms = new ArrayList<>(raws.size()); for (int i = 0, m = raws.size(); i < m; i++) terms.add(toTerm(receivers, raws.get(i), keyspace, boundNames)); return terms; } /** * Renames an identifier in this Relation, if applicable. * @param from the old identifier * @param to the new identifier * @return this object, if the old identifier is not in the set of entities that this relation covers; otherwise * a new Relation with "from" replaced by "to" is returned. */ public abstract Relation renameIdentifier(ColumnIdentifier from, ColumnIdentifier to); /** * Returns a CQL representation of this relation. * * @return a CQL representation of this relation */ public abstract String toCQLString(); @Override public String toString() { return toCQLString(); } }




© 2015 - 2024 Weber Informatics LLC | Privacy Policy