You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucene.apache.org by jb...@apache.org on 2017/12/22 13:17:21 UTC

[1/2] lucene-solr:master: SOLR-11789: Add integrate Stream Evaluator

Repository: lucene-solr
Updated Branches:
  refs/heads/master 091f45dd7 -> efbbc9e34


SOLR-11789: Add integrate Stream Evaluator


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/b5d55b86
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/b5d55b86
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/b5d55b86

Branch: refs/heads/master
Commit: b5d55b86dfca27d783915e4523cae76869cf67c9
Parents: 091f45d
Author: Joel Bernstein <jb...@apache.org>
Authored: Thu Dec 21 20:42:52 2017 -0500
Committer: Joel Bernstein <jb...@apache.org>
Committed: Fri Dec 22 07:57:41 2017 -0500

----------------------------------------------------------------------
 .../org/apache/solr/handler/StreamHandler.java  |  1 +
 .../solrj/io/eval/IntegrateEvaluator.java       | 70 ++++++++++++++++++++
 .../solrj/io/stream/StreamExpressionTest.java   | 26 ++++++++
 3 files changed, 97 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/b5d55b86/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
----------------------------------------------------------------------
diff --git a/solr/core/src/java/org/apache/solr/handler/StreamHandler.java b/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
index 949a040..67d6f7f 100644
--- a/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
+++ b/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
@@ -284,6 +284,7 @@ public class StreamHandler extends RequestHandlerBase implements SolrCoreAware,
         .withFunctionName("ttest", TTestEvaluator.class)
         .withFunctionName("pairedTtest", PairedTTestEvaluator.class)
         .withFunctionName("multiVariateNormalDistribution", MultiVariateNormalDistributionEvaluator.class)
+        .withFunctionName("integrate", IntegrateEvaluator.class)
 
         // Boolean Stream Evaluators
 

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/b5d55b86/solr/solrj/src/java/org/apache/solr/client/solrj/io/eval/IntegrateEvaluator.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/io/eval/IntegrateEvaluator.java b/solr/solrj/src/java/org/apache/solr/client/solrj/io/eval/IntegrateEvaluator.java
new file mode 100644
index 0000000..277748c
--- /dev/null
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/io/eval/IntegrateEvaluator.java
@@ -0,0 +1,70 @@
+/*
+ * 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.solr.client.solrj.io.eval;
+
+import java.io.IOException;
+import java.util.Locale;
+
+import org.apache.commons.math3.analysis.UnivariateFunction;
+import org.apache.commons.math3.analysis.integration.RombergIntegrator;
+import org.apache.solr.client.solrj.io.stream.expr.StreamExpression;
+import org.apache.solr.client.solrj.io.stream.expr.StreamFactory;
+
+public class IntegrateEvaluator extends RecursiveObjectEvaluator implements ManyValueWorker {
+  protected static final long serialVersionUID = 1L;
+
+  public IntegrateEvaluator(StreamExpression expression, StreamFactory factory) throws IOException{
+    super(expression, factory);
+  }
+
+  @Override
+  public Object doWork(Object... values) throws IOException {
+
+    if(values.length != 3) {
+      throw new IOException("The integrate function requires 3 parameters");
+    }
+
+    if (!(values[0] instanceof VectorFunction)) {
+      throw new IOException(String.format(Locale.ROOT, "Invalid expression %s - found type %s for the first value, expecting a FunctionVector", toExpression(constructingFactory), values[0].getClass().getSimpleName()));
+    }
+
+    VectorFunction vectorFunction = (VectorFunction) values[0];
+    if(!(vectorFunction.getFunction() instanceof UnivariateFunction)) {
+      throw new IOException("Cannot evaluate integral from parameter.");
+    }
+
+    Number min = null;
+    Number max = null;
+
+    if(values[1] instanceof Number) {
+      min = (Number) values[1];
+    } else {
+      throw new IOException("The second parameter of the integrate function must be a number");
+    }
+
+    if(values[2] instanceof Number ) {
+      max = (Number) values[2];
+    } else {
+      throw new IOException("The third parameter of the integrate function must be a number");
+    }
+
+    UnivariateFunction func = (UnivariateFunction)vectorFunction.getFunction();
+
+    RombergIntegrator rombergIntegrator = new RombergIntegrator();
+    return rombergIntegrator.integrate(5000, func, min.doubleValue(), max.doubleValue());
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/b5d55b86/solr/solrj/src/test/org/apache/solr/client/solrj/io/stream/StreamExpressionTest.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/io/stream/StreamExpressionTest.java b/solr/solrj/src/test/org/apache/solr/client/solrj/io/stream/StreamExpressionTest.java
index 01ba1dd..a9f0f66 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/io/stream/StreamExpressionTest.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/io/stream/StreamExpressionTest.java
@@ -7228,6 +7228,32 @@ public class StreamExpressionTest extends SolrCloudTestCase {
 
 
   @Test
+  public void testIntegrate() throws Exception {
+    String cexpr = "let(echo=true, " +
+                       "a=sequence(50, 1, 0), " +
+                       "b=spline(a), " +
+                       "c=integrate(b, 0, 49), " +
+                       "d=integrate(b, 0, 20), " +
+                       "e=integrate(b, 20, 49))";
+    ModifiableSolrParams paramsLoc = new ModifiableSolrParams();
+    paramsLoc.set("expr", cexpr);
+    paramsLoc.set("qt", "/stream");
+    String url = cluster.getJettySolrRunners().get(0).getBaseUrl().toString()+"/"+COLLECTIONORALIAS;
+    TupleStream solrStream = new SolrStream(url, paramsLoc);
+    StreamContext context = new StreamContext();
+    solrStream.setStreamContext(context);
+    List<Tuple> tuples = getTuples(solrStream);
+    assertTrue(tuples.size() == 1);
+    Number integral = (Number)tuples.get(0).get("c");
+    assertEquals(integral.doubleValue(), 49, 0.0);
+    integral = (Number)tuples.get(0).get("d");
+    assertEquals(integral.doubleValue(), 20, 0.0);
+    integral = (Number)tuples.get(0).get("e");
+    assertEquals(integral.doubleValue(), 29, 0.0);
+  }
+
+
+  @Test
   public void testLoess() throws Exception {
     String cexpr = "let(echo=true," +
                    "    a=array(0,1,2,3,4,5,6,7)," +


[2/2] lucene-solr:master: SOLR-11754: Fix precommit

Posted by jb...@apache.org.
SOLR-11754: Fix precommit


Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/efbbc9e3
Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/efbbc9e3
Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/efbbc9e3

Branch: refs/heads/master
Commit: efbbc9e344ac803a49d587ebad0f83d0f0a38908
Parents: b5d55b8
Author: Joel Bernstein <jb...@apache.org>
Authored: Fri Dec 22 08:17:08 2017 -0500
Committer: Joel Bernstein <jb...@apache.org>
Committed: Fri Dec 22 08:17:08 2017 -0500

----------------------------------------------------------------------
 .../org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java   | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/efbbc9e3/solr/solrj/src/test/org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/test/org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java b/solr/solrj/src/test/org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java
index 76c4e5b..5f4a0a6 100644
--- a/solr/solrj/src/test/org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java
+++ b/solr/solrj/src/test/org/apache/solr/client/solrj/MergeIndexesExampleTestBase.java
@@ -25,7 +25,6 @@ import org.apache.solr.common.SolrInputDocument;
 import org.apache.solr.common.params.CoreAdminParams;
 import org.apache.solr.common.params.SolrParams;
 import org.apache.solr.core.CoreContainer;
-import org.junit.BeforeClass;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;