• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

Java IndexOperator类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了Java中org.apache.cassandra.thrift.IndexOperator的典型用法代码示例。如果您正苦于以下问题:Java IndexOperator类的具体用法?Java IndexOperator怎么用?Java IndexOperator使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



IndexOperator类属于org.apache.cassandra.thrift包,在下文中一共展示了IndexOperator类的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Java代码示例。

示例1: getIndexOperator

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
/**
 * Returns IndexOperator from string representation
 * @param operator - string representing IndexOperator (=, >=, >, <, <=)
 * @return IndexOperator - enum value of IndexOperator or null if not found
 */
public static IndexOperator getIndexOperator(String operator)
{
    if (operator.equals("="))
    {
        return IndexOperator.EQ;
    }
    else if (operator.equals(">="))
    {
        return IndexOperator.GTE;
    }
    else if (operator.equals(">"))
    {
        return IndexOperator.GT;
    }
    else if (operator.equals("<"))
    {
        return IndexOperator.LT;
    }
    else if (operator.equals("<="))
    {
        return IndexOperator.LTE;
    }

    return null;
}
 
开发者ID:vcostet,项目名称:cassandra-kmean,代码行数:31,代码来源:CliUtils.java


示例2: getPriority

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static int getPriority(IndexOperator op)
{
    switch (op)
    {
        case EQ:
            return 4;

        case GTE:
        case GT:
            return 3;

        case LTE:
        case LT:
            return 2;

        case NOT_EQ:
            return 1;

        default:
            return 0;
    }
}
 
开发者ID:xedin,项目名称:sasi,代码行数:23,代码来源:Operation.java


示例3: testSatisfiedByWithMultipleTerms

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
@Test
public void testSatisfiedByWithMultipleTerms()
{
    final ByteBuffer comment = UTF8Type.instance.decompose("comment");
    final ColumnFamilyStore store = Keyspace.open("sasecondaryindex").getColumnFamilyStore("saindexed1");
    final IPartitioner<?> partitioner = StorageService.getPartitioner();

    ColumnFamily cf = ArrayBackedSortedColumns.factory.create(store.metadata);
    cf.addColumn(new Column(comment, UTF8Type.instance.decompose("software engineer is working on a project"), System.currentTimeMillis()));

    Operation.Builder builder = new Operation.Builder(OperationType.AND, UTF8Type.instance, controller,
                                        new IndexExpression(comment, IndexOperator.EQ, UTF8Type.instance.decompose("eng is a work")));
    Operation op = builder.complete();

    Assert.assertTrue(op.satisfiedBy(new Row(partitioner.decorateKey(UTF8Type.instance.decompose("key1")), cf), null, false));

    builder = new Operation.Builder(OperationType.AND, UTF8Type.instance, controller,
                                        new IndexExpression(comment, IndexOperator.EQ, UTF8Type.instance.decompose("soft works fine")));
    op = builder.complete();

    Assert.assertTrue(op.satisfiedBy(new Row(partitioner.decorateKey(UTF8Type.instance.decompose("key1")), cf), null, false));
}
 
开发者ID:xedin,项目名称:sasi,代码行数:23,代码来源:OperationTest.java


示例4: satisfies

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
public static boolean satisfies(int comparison, IndexOperator op)
{
    switch (op)
    {
        case EQ:
            return comparison == 0;
        case GTE:
            return comparison >= 0;
        case GT:
            return comparison > 0;
        case LTE:
            return comparison <= 0;
        case LT:
            return comparison < 0;
        default:
            throw new IllegalStateException();
    }
}
 
开发者ID:dprguiuc,项目名称:Cassandra-Wasef,代码行数:19,代码来源:ExtendedFilter.java


示例5: highestSelectivityPredicate

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private IndexExpression highestSelectivityPredicate(IndexClause clause)
{
    IndexExpression best = null;
    int bestMeanCount = Integer.MAX_VALUE;
    for (IndexExpression expression : clause.expressions)
    {
        ColumnFamilyStore cfs = getIndexedColumnFamilyStore(expression.column_name);
        if (cfs == null || !expression.op.equals(IndexOperator.EQ))
            continue;
        int columns = cfs.getMeanColumns();
        if (columns < bestMeanCount)
        {
            best = expression;
            bestMeanCount = columns;
        }
    }
    return best;
}
 
开发者ID:devdattakulkarni,项目名称:Cassandra-KVPM,代码行数:19,代码来源:ColumnFamilyStore.java


示例6: satisfies

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static boolean satisfies(int comparison, IndexOperator op)
{
    switch (op)
    {
        case EQ:
            return comparison == 0;
        case GTE:
            return comparison >= 0;
        case GT:
            return comparison > 0;
        case LTE:
            return comparison <= 0;
        case LT:
            return comparison < 0;
        default:
            throw new IllegalStateException();
    }
}
 
开发者ID:devdattakulkarni,项目名称:Cassandra-KVPM,代码行数:19,代码来源:ColumnFamilyStore.java


示例7: expressionFor

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static Expression expressionFor(long lower, boolean lowerInclusive, long upper, boolean upperInclusive)
{
    Expression expression = new Expression(ByteBufferUtil.EMPTY_BYTE_BUFFER, LongType.instance);
    expression.add(lowerInclusive ? IndexOperator.GTE : IndexOperator.GT, LongType.instance.decompose(lower));
    expression.add(upperInclusive ? IndexOperator.LTE : IndexOperator.LT, LongType.instance.decompose(upper));
    return expression;
}
 
开发者ID:xedin,项目名称:sasi,代码行数:8,代码来源:OnDiskIndexTest.java


示例8: expressionForNot

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static Expression expressionForNot(AbstractType<?> validator, ByteBuffer lower, ByteBuffer upper, Iterable<ByteBuffer> terms)
{
    Expression expression = new Expression(ByteBufferUtil.EMPTY_BYTE_BUFFER, validator);
    expression.setOp(Expression.Op.RANGE);
    expression.setLower(new Expression.Bound(lower, true));
    expression.setUpper(new Expression.Bound(upper, true));
    for (ByteBuffer term : terms)
        expression.add(IndexOperator.NOT_EQ, term);
    return expression;

}
 
开发者ID:xedin,项目名称:sasi,代码行数:12,代码来源:OnDiskIndexTest.java


示例9: rangeWithExclusions

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static Expression rangeWithExclusions(long lower, boolean lowerInclusive, long upper, boolean upperInclusive, Set<Long> exclusions)
{
    Expression expression = expressionFor(lower, lowerInclusive, upper, upperInclusive);
    for (long e : exclusions)
        expression.add(IndexOperator.NOT_EQ, LongType.instance.decompose(e));

    return expression;
}
 
开发者ID:xedin,项目名称:sasi,代码行数:9,代码来源:OnDiskIndexTest.java


示例10: getIndexOperator

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
public IndexOperator getIndexOperator(Bound b)
{
    switch (b)
    {
        case START:
            return boundInclusive[b.idx] ? IndexOperator.GTE : IndexOperator.GT;
        case END:
            return boundInclusive[b.idx] ? IndexOperator.LTE : IndexOperator.LT;
    }
    throw new AssertionError();
}
 
开发者ID:dprguiuc,项目名称:Cassandra-Wasef,代码行数:12,代码来源:SelectStatement.java


示例11: analyzeGroup

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
@VisibleForTesting
protected static ListMultimap<ByteBuffer, Expression> analyzeGroup(QueryController controller,
                                                                   final AbstractType<?> comparator,
                                                                   OperationType op,
                                                                   List<IndexExpression> expressions)
{
    ListMultimap<ByteBuffer, Expression> analyzed = ArrayListMultimap.create();

    // sort all of the expressions in the operation by name and priority of the logical operator
    // this gives us an efficient way to handle inequality and combining into ranges without extra processing
    // and converting expressions from one type to another.
    Collections.sort(expressions, new Comparator<IndexExpression>()
    {
        @Override
        public int compare(IndexExpression a, IndexExpression b)
        {
            int cmp = comparator.compare(ByteBuffer.wrap(a.getColumn_name()), ByteBuffer.wrap(b.getColumn_name()));
            return cmp == 0 ? -Integer.compare(getPriority(a.getOp()), getPriority(b.getOp())) : cmp;
        }
    });

    for (final IndexExpression e : expressions)
    {
        if (e.isSetLogicalOp())
            continue;

        ByteBuffer name = ByteBuffer.wrap(e.getColumn_name());
        ColumnIndex columnIndex = controller.getIndex(name);

        List<Expression> perColumn = analyzed.get(name);

        if (columnIndex == null)
        {
            ColumnDefinition nonIndexedColumn = controller.getColumn(name);
            columnIndex = new ColumnIndex(controller.getKeyValidator(),
                                          nonIndexedColumn,
                                          controller.getComparator(nonIndexedColumn));
        }

        AbstractAnalyzer analyzer = columnIndex.getAnalyzer();
        analyzer.reset(ByteBuffer.wrap(e.getValue()));

        // EQ/NOT_EQ can have multiple expressions e.g. text = "Hello World",
        // becomes text = "Hello" OR text = "World" because "space" is always interpreted as a split point (by analyzer),
        // NOT_EQ is made an independent expression only in case of pre-existing multiple EQ expressions, or
        // if there is no EQ operations and NOT_EQ is met or a single NOT_EQ expression present,
        // in such case we know exactly that there would be no more EQ/RANGE expressions for given column
        // since NOT_EQ has the lowest priority.
        if (e.getOp() == IndexOperator.EQ
                || (e.getOp() == IndexOperator.NOT_EQ
                   && (perColumn.size() == 0 || perColumn.size() > 1
                       || (perColumn.size() == 1 && perColumn.get(0).getOp() == Op.NOT_EQ))))
        {
            while (analyzer.hasNext())
            {
                final ByteBuffer token = analyzer.next();
                perColumn.add(new Expression(controller, columnIndex)
                {{
                        add(e.op, token);
                }});
            }
        }
        else
        // "range" or not-equals operator, combines both bounds together into the single expression,
        // iff operation of the group is AND, otherwise we are forced to create separate expressions,
        // not-equals is combined with the range iff operator is AND.
        {
            Expression range;
            if (perColumn.size() == 0 || op != OperationType.AND)
                perColumn.add((range = new Expression(controller, columnIndex)));
            else
                range = Iterables.getLast(perColumn);

            while (analyzer.hasNext())
                range.add(e.op, analyzer.next());
        }
    }

    return analyzed;
}
 
开发者ID:xedin,项目名称:sasi,代码行数:81,代码来源:Operation.java


示例12: add

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
public Expression add(IndexOperator op, ByteBuffer value)
{
    boolean lowerInclusive = false, upperInclusive = false;
    switch (op)
    {
        case EQ:
            lower = new Bound(value, true);
            upper = lower;
            operation = Op.EQ;
            break;

        case NOT_EQ:
            // index expressions are priority sorted
            // and NOT_EQ is the lowest priority, which means that operation type
            // is always going to be set before reaching it in case of RANGE or EQ.
            if (operation == null)
            {
                operation = Op.NOT_EQ;
                lower = new Bound(value, true);
                upper = lower;
            }
            else
                exclusions.add(value);
            break;

        case LTE:
            upperInclusive = true;
        case LT:
            operation = Op.RANGE;
            upper = new Bound(value, upperInclusive);
            break;

        case GTE:
            lowerInclusive = true;
        case GT:
            operation = Op.RANGE;
            lower = new Bound(value, lowerInclusive);
            break;
    }

    return this;
}
 
开发者ID:xedin,项目名称:sasi,代码行数:43,代码来源:Expression.java


示例13: testRangeQueryWithExclusions

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
@Test
public void testRangeQueryWithExclusions() throws Exception
{
    final long lower = 0;
    final long upper = 100000;

    OnDiskIndexBuilder builder = new OnDiskIndexBuilder(UTF8Type.instance, LongType.instance, OnDiskIndexBuilder.Mode.SPARSE);
    for (long i = lower; i <= upper; i++)
        builder.add(LongType.instance.decompose(i), keyAt(i), i);

    File index = File.createTempFile("on-disk-sa-except-long-ranges", "db");
    index.deleteOnExit();

    builder.finish(index);

    OnDiskIndex onDisk = new OnDiskIndex(index, LongType.instance, new KeyConverter());

    ThreadLocalRandom random = ThreadLocalRandom.current();

    // single exclusion

    // let's do small range first to figure out if searchPoint works properly
    validateExclusions(onDisk, lower, 50, Sets.newHashSet(42L));
    // now let's do whole data set to test SPARSE searching
    validateExclusions(onDisk, lower, upper, Sets.newHashSet(31337L));

    // pair of exclusions which would generate a split

    validateExclusions(onDisk, lower, random.nextInt(400, 800), Sets.newHashSet(42L, 154L));
    validateExclusions(onDisk, lower, upper, Sets.newHashSet(31337L, 54631L));

    // 3 exclusions which would generate a split and change bounds

    validateExclusions(onDisk, lower, random.nextInt(400, 800), Sets.newHashSet(42L, 154L));
    validateExclusions(onDisk, lower, upper, Sets.newHashSet(31337L, 54631L));

    validateExclusions(onDisk, lower, random.nextLong(400, upper), Sets.newHashSet(42L, 55L));
    validateExclusions(onDisk, lower, random.nextLong(400, upper), Sets.newHashSet(42L, 55L, 93L));
    validateExclusions(onDisk, lower, random.nextLong(400, upper), Sets.newHashSet(42L, 55L, 93L, 205L));

    Set<Long> exclusions = Sets.newHashSet(3L, 12L, 13L, 14L, 27L, 54L, 81L, 125L, 384L, 771L, 1054L, 2048L, 78834L);

    // test that exclusions are properly bound by lower/upper of the expression
    Assert.assertEquals(392, validateExclusions(onDisk, lower, 400, exclusions, false));
    Assert.assertEquals(101, validateExclusions(onDisk, lower, 100, Sets.newHashSet(-10L, -5L, -1L), false));

    validateExclusions(onDisk, lower, upper, exclusions);

    Assert.assertEquals(100000, convert(onDisk.search(new Expression(ByteBufferUtil.EMPTY_BYTE_BUFFER, LongType.instance)
                                                .add(IndexOperator.NOT_EQ, LongType.instance.decompose(100L)))).size());

    Assert.assertEquals(49, convert(onDisk.search(new Expression(ByteBufferUtil.EMPTY_BYTE_BUFFER, LongType.instance)
                                                .add(IndexOperator.LT, LongType.instance.decompose(50L))
                                                .add(IndexOperator.NOT_EQ, LongType.instance.decompose(10L)))).size());

    Assert.assertEquals(99998, convert(onDisk.search(new Expression(ByteBufferUtil.EMPTY_BYTE_BUFFER, LongType.instance)
                                                .add(IndexOperator.GT, LongType.instance.decompose(1L))
                                                .add(IndexOperator.NOT_EQ, LongType.instance.decompose(20L)))).size());

    onDisk.close();
}
 
开发者ID:xedin,项目名称:sasi,代码行数:62,代码来源:OnDiskIndexTest.java


示例14: testAnalyzeNotIndexedButDefinedColumn

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
@Test
public void testAnalyzeNotIndexedButDefinedColumn() throws Exception
{
    final ByteBuffer firstName = UTF8Type.instance.decompose("first_name");
    final ByteBuffer height = UTF8Type.instance.decompose("height");
    final ByteBuffer notDefined = UTF8Type.instance.decompose("not-defined");

    // first_name = 'a' AND height != 10
    Map<Expression.Op, Expression> expressions;
    expressions = convert(Operation.analyzeGroup(controller, UTF8Type.instance, OperationType.AND,
            Arrays.asList(new IndexExpression(firstName, IndexOperator.EQ, UTF8Type.instance.decompose("a")),
                          new IndexExpression(height, IndexOperator.NOT_EQ, Int32Type.instance.decompose(5)))));

    Assert.assertEquals(2, expressions.size());

    Assert.assertEquals(new Expression(height, Int32Type.instance)
    {{
            operation = Op.NOT_EQ;
            lower = new Bound(Int32Type.instance.decompose(5), true);
            upper = lower;
    }}, expressions.get(Expression.Op.NOT_EQ));

    expressions = convert(Operation.analyzeGroup(controller, UTF8Type.instance, OperationType.AND,
            Arrays.asList(new IndexExpression(firstName, IndexOperator.EQ, UTF8Type.instance.decompose("a")),
                          new IndexExpression(height, IndexOperator.GT, Int32Type.instance.decompose(0)),
                          new IndexExpression(height, IndexOperator.NOT_EQ, Int32Type.instance.decompose(5)))));

    Assert.assertEquals(2, expressions.size());

    Assert.assertEquals(new Expression(height, Int32Type.instance)
    {{
        operation = Op.RANGE;
        lower = new Bound(Int32Type.instance.decompose(0), false);
        exclusions.add(Int32Type.instance.decompose(5));
    }}, expressions.get(Expression.Op.RANGE));

    expressions = convert(Operation.analyzeGroup(controller, UTF8Type.instance, OperationType.AND,
            Arrays.asList(new IndexExpression(firstName, IndexOperator.EQ, UTF8Type.instance.decompose("a")),
                          new IndexExpression(height, IndexOperator.NOT_EQ, Int32Type.instance.decompose(5)),
                          new IndexExpression(height, IndexOperator.GTE, Int32Type.instance.decompose(0)),
                          new IndexExpression(height, IndexOperator.LT, Int32Type.instance.decompose(10)))));

    Assert.assertEquals(2, expressions.size());

    Assert.assertEquals(new Expression(height, Int32Type.instance)
    {{
            operation = Op.RANGE;
            lower = new Bound(Int32Type.instance.decompose(0), true);
            upper = new Bound(Int32Type.instance.decompose(10), false);
            exclusions.add(Int32Type.instance.decompose(5));
    }}, expressions.get(Expression.Op.RANGE));


    expressions = convert(Operation.analyzeGroup(controller, UTF8Type.instance, OperationType.AND,
                    new ArrayList<IndexExpression>() {{ add(new IndexExpression(notDefined, IndexOperator.EQ, UTF8Type.instance.decompose("a"))); }}));

    Assert.assertEquals(1, expressions.size());
}
 
开发者ID:xedin,项目名称:sasi,代码行数:59,代码来源:OperationTest.java


示例15: multiRangeSlice

import org.apache.cassandra.thrift.IndexOperator; //导入依赖的package包/类
private static List<org.apache.cassandra.db.Row> multiRangeSlice(CFMetaData metadata, SelectStatement select, List<ByteBuffer> variables)
throws ReadTimeoutException, UnavailableException, InvalidRequestException
{
    IPartitioner<?> p = StorageService.getPartitioner();

    AbstractType<?> keyType = Schema.instance.getCFMetaData(metadata.ksName, select.getColumnFamily()).getKeyValidator();

    ByteBuffer startKeyBytes = (select.getKeyStart() != null)
                               ? select.getKeyStart().getByteBuffer(keyType,variables)
                               : null;

    ByteBuffer finishKeyBytes = (select.getKeyFinish() != null)
                                ? select.getKeyFinish().getByteBuffer(keyType,variables)
                                : null;

    RowPosition startKey = RowPosition.forKey(startKeyBytes, p), finishKey = RowPosition.forKey(finishKeyBytes, p);
    if (startKey.compareTo(finishKey) > 0 && !finishKey.isMinimum(p))
    {
        if (p instanceof RandomPartitioner)
            throw new InvalidRequestException("Start key sorts after end key. This is not allowed; you probably should not specify end key at all, under RandomPartitioner");
        else
            throw new InvalidRequestException("Start key must sort before (or equal to) finish key in your partitioner!");
    }
    AbstractBounds<RowPosition> bounds = new Bounds<RowPosition>(startKey, finishKey);

    IDiskAtomFilter columnFilter = filterFromSelect(select, metadata, variables);
    validateFilter(metadata, columnFilter);

    List<Relation> columnRelations = select.getColumnRelations();
    List<IndexExpression> expressions = new ArrayList<IndexExpression>(columnRelations.size());
    for (Relation columnRelation : columnRelations)
    {
        // Left and right side of relational expression encoded according to comparator/validator.
        ByteBuffer entity = columnRelation.getEntity().getByteBuffer(metadata.comparator, variables);
        ByteBuffer value = columnRelation.getValue().getByteBuffer(select.getValueValidator(metadata.ksName, entity), variables);

        expressions.add(new IndexExpression(entity,
                                            IndexOperator.valueOf(columnRelation.operator().toString()),
                                            value));
    }

    int limit = select.isKeyRange() && select.getKeyStart() != null
              ? select.getNumRecords() + 1
              : select.getNumRecords();

    List<org.apache.cassandra.db.Row> rows = StorageProxy.getRangeSlice(new RangeSliceCommand(metadata.ksName,
                                                                                              select.getColumnFamily(),
                                                                                              null,
                                                                                              columnFilter,
                                                                                              bounds,
                                                                                              expressions,
                                                                                              limit),
                                                                        select.getConsistencyLevel());

    // if start key was set and relation was "greater than"
    if (select.getKeyStart() != null && !select.includeStartKey() && !rows.isEmpty())
    {
        if (rows.get(0).key.key.equals(startKeyBytes))
            rows.remove(0);
    }

    // if finish key was set and relation was "less than"
    if (select.getKeyFinish() != null && !select.includeFinishKey() && !rows.isEmpty())
    {
        int lastIndex = rows.size() - 1;
        if (rows.get(lastIndex).key.key.equals(finishKeyBytes))
            rows.remove(lastIndex);
    }

    return rows.subList(0, select.getNumRecords() < rows.size() ? select.getNumRecords() : rows.size());
}
 
开发者ID:dprguiuc,项目名称:Cassandra-Wasef,代码行数:72,代码来源:QueryProcessor.java



注:本文中的org.apache.cassandra.thrift.IndexOperator类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Java Getter类代码示例发布时间:2022-05-22
下一篇:
Java RemoteAddrValve类代码示例发布时间:2022-05-22
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap