Examples of Index


Examples of at.jku.sii.sqlitereader.model.Index

    @SuppressWarnings("unchecked")
    BTreePage<IndexCell> tree = (BTreePage<IndexCell>) BTreePages.read(db, this.rootpage);
    assert (!tree.isTable()); // must be a table

    tree.resolve(db);
    this.index = new Index(this, tree);
  }
View Full Code Here

Examples of bm.db.index.Index

        System.out.println( "listBrowser: " + listBrowser );
        System.out.println( "IconSets: " + iconSets.size() );
        System.out.println( "Controllers: " + controllers.size() );
        System.out.println( "Views: " + views.size() );

        final Index index = new Index( "sys_compiled_views", order, Index.KT_STRING, true, false );
        final Store store = Store.get( "sys_compiled_views", 1 );
        index.setRecordStore( store );
        if( listBrowser != null && listBrowser.equalsIgnoreCase( "native" ) )
        {
            try
            {
                index.insertObject( "listBrowserMode", "native" );
            }
            catch( Exception e )
            {
                throw new ViewCompilerException( e );
            }
View Full Code Here

Examples of com.alibaba.wasp.meta.Index

      }
      qp = new LocalQueryPlan((GetAction) action);
      LOG.debug(QueryInfo.QueryType.GET + "  "
          + Bytes.toStringBinary(primaryKey) + " from " + table.getTableName());
    } else if (queryInfo.getType() == QueryInfo.QueryType.SCAN) {
      Index index = metaEventOperation.checkAndGetIndex(table,
          queryInfo.getAllConditionFieldName());

      if (index == null) {
        throw new UnsupportedException("Don't get a Index!");
      }

      boolean isJustUseIndex = index.getIndexKeys().size() >= queryInfo.getAllConditionFieldName().size();
      Pair<byte[], byte[]> startKeyAndEndKey = metaEventOperation.getStartkeyAndEndkey(index, queryInfo);

      Pair<List<ColumnStruct>, List<ColumnStruct>> columnActionPair = this
          .buildEntityColumnsForScan(table, index, metaEventOperation,
              selectItem);
View Full Code Here

Examples of com.dianping.cat.consumer.dependency.model.entity.Index

    if (m_exceptions.contains(type)) {
      long current = event.getTimestamp() / 1000 / 60;
      int min = (int) (current % (60));
      Segment segment = report.findOrCreateSegment(min);
      Index index = segment.findOrCreateIndex("Exception");

      index.incTotalCount();
      index.incErrorCount();
    }
  }
View Full Code Here

Examples of com.facebook.presto.spi.Index

            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, Functions.forMap(node.getAssignments()));
            List<ColumnHandle> outputSchema = Lists.transform(node.getOutputSymbols(), Functions.forMap(node.getAssignments()));
            Index index = indexManager.getIndex(node.getIndexHandle(), lookupSchema, outputSchema);

            List<Type> types = getSourceOperatorTypes(node, context.getTypes());
            OperatorFactory operatorFactory = new IndexSourceOperator.IndexSourceOperatorFactory(context.getNextOperatorId(), node.getId(), index, types, probeKeyNormalizer);
            return new PhysicalOperation(operatorFactory, outputMappings.build());
        }
View Full Code Here

Examples of com.flaptor.hounder.Index

            String s = "Destination directory exists. The main index should be in an uncorrupted state, so you may try to recover it.";
            logger.error(s);
            throw new IllegalStateException(s);
        } else {
            // Make a copy
            Index newIndexCopy = index.copyIndex(newCopyDir);
            // Set the hostname on the descriptor
            newIndexCopy.getIndexDescriptor().setRsyncAccessString(rsyncAccessString);
            // Close the copy
            newIndexCopy.close();

            // reset the variable that counts inited threads.
            synchronized(updaters) {
                inited = 0;
            }
View Full Code Here

Examples of com.foundationdb.ais.model.Index

        return groupIndexScanCreator(cID, INDEX_NAME);
    }

    @Override
    protected void postCheckAIS(AkibanInformationSchema ais) {
        Index newIndex = ais.getTable(cID).getGroup().getIndex(INDEX_NAME);
        assertNotNull("new index", newIndex);
    }
View Full Code Here

Examples of com.gemstone.gemfire.cache.query.Index

    index = createIndex(queryService, indexName);
  }

  private Index createIndex(QueryService queryService, String indexName) throws Exception {

    Index existingIndex = null;
   
    for (Index idx : queryService.getIndexes()) {
      if (idx.getName().equals(indexName)) {
        existingIndex = idx;
         break;
      }
    }
    if (existingIndex != null) {
      if (!override) {
        return existingIndex;
      } else {
        queryService.removeIndex(existingIndex);
      }
    }

    Index index = null;
    try {
      if ("KEY".equalsIgnoreCase(type) || "PRIMARY_KEY".equalsIgnoreCase(type)) {

        index = queryService.createKeyIndex(indexName, expression, from);
View Full Code Here

Examples of com.gistlabs.mechanize.util.css_query.NodeHelper.Index

   *
   * @see <a href="http://www.w3.org/TR/css3-selectors/#first-child-pseudo"><code>:first-child</code> pseudo-class</a>
   */
  private void addFirstChildElements() {
    for (Node node : nodes) {
      Index index = helper.getIndexInParent(node, false);
      if (index.index == 0)
        result.add(node);
    }
  }
View Full Code Here

Examples of com.google.appengine.api.datastore.Index

        boolean exist = false;

        Map<Index, IndexState> indexes = service.getIndexes();
        assertTrue(indexes.size() > 0);
        for (Map.Entry<Index, IndexState> entry : indexes.entrySet()) {
            Index index = entry.getKey();
            if (index.getKind().equals("indextest2")) {
                exist = true;
                assertEquals(Index.IndexState.SERVING, entry.getValue());
                for (Property property : index.getProperties()) {
                    if (property.getName().equals("stringData")) {
                        assertEquals(Query.SortDirection.DESCENDING, property.getDirection());
                    } else if (property.getName().equals("age")) {
                        assertEquals(Query.SortDirection.ASCENDING, property.getDirection());
                    }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.