Examples of optimize()


Examples of org.apache.solr.client.solrj.impl.CommonsHttpSolrServer.optimize()

      docs.add(doc);
    }

    solr.add(docs);
    solr.commit();
    solr.optimize();
    //<start id="solrj-search-1"/>
    SolrQuery queryParams = new SolrQuery();//<co id="solrj-search.co.query"/>
    queryParams.setFields("description", "title");//<co id="solrj-search.co.fields"/>
    queryParams.setQuery("description:win OR description:all");//<co id="solrj-search.co.terms"/>
    queryParams.setRows(10);
View Full Code Here

Examples of org.apache.solr.client.solrj.impl.HttpSolrServer.optimize()

           
            context.removeCached(dso, id);
            solr.add(sdi);
        }
        solr.commit();
        solr.optimize();

        sdl = indexer.getRawData(CrisConstants.RP_TYPE_ID);
        System.out.println("Found " + sdl.getNumFound()
                + " access in the RP statistics core");
        HttpSolrServer rpsolr = indexer.getSolr();
View Full Code Here

Examples of org.apache.tajo.engine.planner.LogicalOptimizer.optimize()

    LogicalPlanner planner = new LogicalPlanner(catalog);
    LogicalOptimizer optimizer = new LogicalOptimizer(conf);
    Expr expr =  analyzer.parse(query);
    LogicalPlan plan = planner.createPlan(LocalTajoTestingUtility.createDummySession(), expr);

    optimizer.optimize(plan);

    QueryId queryId = QueryIdFactory.newQueryId(System.currentTimeMillis(), 0);
    QueryContext queryContext = new QueryContext();
    MasterPlan masterPlan = new MasterPlan(queryId, queryContext, plan);
    GlobalPlanner globalPlanner = new GlobalPlanner(conf, catalog);
View Full Code Here

Examples of org.elasticsearch.index.shard.service.IndexShard.optimize()

    }

    @Override protected ShardOptimizeResponse shardOperation(ShardOptimizeRequest request) throws ElasticSearchException {
        synchronized (optimizeMutex) {
            IndexShard indexShard = indicesService.indexServiceSafe(request.index()).shardSafe(request.shardId());
            indexShard.optimize(new Engine.Optimize()
                    .waitForMerge(request.waitForMerge())
                    .maxNumSegments(request.maxNumSegments())
                    .onlyExpungeDeletes(request.onlyExpungeDeletes())
                    .flush(request.flush())
                    .refresh(request.refresh())
View Full Code Here

Examples of org.exist.indexing.lucene.LuceneIndexWorker.optimize()

        if (!context.getUser().hasDbaRole())
            throw new XPathException(this, "user has to be a member of the dba group to call " +
                "the optimize function. Calling user was " + context.getUser().getName());
        LuceneIndexWorker index = (LuceneIndexWorker)
                context.getBroker().getIndexController().getWorkerByIndexId(LuceneIndex.ID);
        index.optimize();
        return Sequence.EMPTY_SEQUENCE;
    }
}
View Full Code Here

Examples of org.exist.indexing.range.RangeIndexWorker.optimize()

    public Sequence eval(Sequence[] args, Sequence contextSequence) throws XPathException {
        if (!context.getUser().hasDbaRole())
            throw new XPathException(this, "user has to be a member of the dba group to call " +
                "the optimize function. Calling user was " + context.getUser().getName());
        RangeIndexWorker index = (RangeIndexWorker) context.getBroker().getIndexController().getWorkerByIndexId(RangeIndex.ID);
        index.optimize();
        return Sequence.EMPTY_SEQUENCE;
    }
}
View Full Code Here

Examples of org.gd.spark.opendl.util.MyConjugateGradient.optimize()

     
    dAOptimizer daopt = new dAOptimizer(config, x_samples, n_visible, n_hidden, curr_w, curr_hbias, curr_vbias);
        MyConjugateGradient cg = new MyConjugateGradient(daopt, config.getCgInitStepSize());
        cg.setTolerance(config.getCgTolerance());
        try {
            cg.optimize(config.getCgMaxIterations());
        } catch (Throwable e) {
            logger.error("", e);
        }
  }
View Full Code Here

Examples of org.h2.expression.Expression.optimize()

                    Column c = columns[i];
                    int index = c.getColumnId();
                    Expression e = expr[i];
                    if (e != null) {
                        // e can be null (DEFAULT)
                        e = e.optimize(session);
                        try {
                            Value v = c.convert(e.getValue(session));
                            newRow.setValue(index, v);
                        } catch (DbException ex) {
                            throw setRow(ex, x, getSQL(expr));
View Full Code Here

Examples of org.hibernate.search.SearchFactory.optimize()

        if (index++ % batchSize == 0)
          session.flush(); // clear every batchSize since the queue is processed
      }
    }
    final SearchFactory searchFactory = fullTextSession.getSearchFactory();
    searchFactory.optimize(clazz);
    log.info("Re-indexing of " + index + " objects of type " + clazz.getName() + " done.");
    return index;
  }

  /**
 
View Full Code Here

Examples of org.hibernate.search.store.optimization.OptimizerStrategy.optimize()

        Workspace.DPStatistics stats = dpStatistics.get( provider );
        if ( !stats.optimizationForced ) {
          OptimizerStrategy optimizerStrategy = searchFactoryImplementor.getOptimizerStrategy( provider );
          optimizerStrategy.addTransaction( stats.operations );
          try {
            optimizerStrategy.optimize( this );
          }
          catch (SearchException e) {
            raisedException = new SearchException( "Exception while optimizing directoryProvider: "
                + provider.getDirectory().toString(), e );
            break; //no point in continuing
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.