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/01/02 16:16:04 UTC

lucene-solr:master: SOLR-9684: Rename schedule function to priority

Repository: lucene-solr
Updated Branches:
  refs/heads/master 93562da61 -> 0999f6779


SOLR-9684: Rename schedule function to priority


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

Branch: refs/heads/master
Commit: 0999f6779a3341af072d31162a2c88cf1eb8c5d4
Parents: 93562da
Author: Joel Bernstein <jb...@apache.org>
Authored: Mon Jan 2 11:08:44 2017 -0500
Committer: Joel Bernstein <jb...@apache.org>
Committed: Mon Jan 2 11:08:44 2017 -0500

----------------------------------------------------------------------
 solr/CHANGES.txt                                |   2 +-
 .../org/apache/solr/handler/StreamHandler.java  |   2 +-
 .../client/solrj/io/stream/PriorityStream.java  | 161 +++++++++++++++++++
 .../client/solrj/io/stream/SchedulerStream.java | 161 -------------------
 .../solrj/io/stream/StreamExpressionTest.java   |  20 +--
 5 files changed, 173 insertions(+), 173 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0999f677/solr/CHANGES.txt
----------------------------------------------------------------------
diff --git a/solr/CHANGES.txt b/solr/CHANGES.txt
index 7133638..6326e54 100644
--- a/solr/CHANGES.txt
+++ b/solr/CHANGES.txt
@@ -208,7 +208,7 @@ New Features
 
 * SOLR-9668,SOLR-7197: introduce cursorMark='true' in SolrEntityProcessor (Yegor Kozlov, Raveendra Yerraguntl via Mikhail Khludnev)
 
-* SOLR-9684: Add schedule Streaming Expression (Joel Bernstein)
+* SOLR-9684: Add priority Streaming Expression (Joel Bernstein, David Smiley)
 
 Optimizations
 ----------------------

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0999f677/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 1610fea..661704f 100644
--- a/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
+++ b/solr/core/src/java/org/apache/solr/handler/StreamHandler.java
@@ -140,7 +140,7 @@ public class StreamHandler extends RequestHandlerBase implements SolrCoreAware,
       .withFunctionName("fetch", FetchStream.class)
       .withFunctionName("executor", ExecutorStream.class)
       .withFunctionName("null", NullStream.class)
-      .withFunctionName("schedule", SchedulerStream.class)
+      .withFunctionName("priority", PriorityStream.class)
       // metrics
       .withFunctionName("min", MinMetric.class)
       .withFunctionName("max", MaxMetric.class)

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0999f677/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/PriorityStream.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/PriorityStream.java b/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/PriorityStream.java
new file mode 100644
index 0000000..c5faf41
--- /dev/null
+++ b/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/PriorityStream.java
@@ -0,0 +1,161 @@
+/*
+ * 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.stream;
+
+import java.io.IOException;
+import java.lang.invoke.MethodHandles;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Locale;
+
+import org.apache.solr.client.solrj.io.Tuple;
+import org.apache.solr.client.solrj.io.comp.StreamComparator;
+import org.apache.solr.client.solrj.io.stream.expr.Explanation;
+import org.apache.solr.client.solrj.io.stream.expr.Explanation.ExpressionType;
+import org.apache.solr.client.solrj.io.stream.expr.Expressible;
+import org.apache.solr.client.solrj.io.stream.expr.StreamExplanation;
+import org.apache.solr.client.solrj.io.stream.expr.StreamExpression;
+import org.apache.solr.client.solrj.io.stream.expr.StreamFactory;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * The priority function wraps two topics that represent high priority and low priority task queues.
+ * Each time the priority function is called it will check to see if there are any high priority tasks in the queue. If there
+ * are high priority tasks, then the high priority queue will be read until it returns the EOF Tuple.
+ *
+ * If there are no tasks in the high priority queue, then the lower priority task queue will be opened and read until the EOF Tuple is
+ * returned.
+ *
+ * The scheduler is designed to be wrapped by the executor function and a daemon function can be used to call the executor iteratively.
+ **/
+
+public class PriorityStream extends TupleStream implements Expressible {
+
+  private static final Logger logger = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass());
+
+  private PushBackStream highPriorityTasks;
+  private PushBackStream tasks;
+  private TupleStream currentStream;
+
+  public PriorityStream(StreamExpression expression, StreamFactory factory) throws IOException {
+    // grab all parameters out
+    List<StreamExpression> streamExpressions = factory.getExpressionOperandsRepresentingTypes(expression, Expressible.class, TupleStream.class);
+
+
+    if(2 != streamExpressions.size()){
+      throw new IOException(String.format(Locale.ROOT,"Invalid expression %s - expecting a single stream but found %d",expression, streamExpressions.size()));
+    }
+
+    TupleStream stream1 = factory.constructStream(streamExpressions.get(0));
+    TupleStream stream2 = factory.constructStream(streamExpressions.get(1));
+
+    if(!(stream1 instanceof TopicStream) || !(stream2 instanceof TopicStream)) {
+      throw new IOException("The scheduler expects both stream parameters to be topics.");
+    }
+
+    init(new PushBackStream(stream1), new PushBackStream(stream2));
+  }
+
+  private void init(PushBackStream stream1, PushBackStream stream2) throws IOException{
+    this.highPriorityTasks = stream1;
+    this.tasks = stream2;
+  }
+
+  @Override
+  public StreamExpression toExpression(StreamFactory factory) throws IOException {
+    return toExpression(factory, true);
+  }
+
+  private StreamExpression toExpression(StreamFactory factory, boolean includeStreams) throws IOException {
+
+    // function name
+    StreamExpression expression = new StreamExpression(factory.getFunctionName(this.getClass()));
+
+    // stream
+    if(includeStreams) {
+      if (highPriorityTasks instanceof Expressible) {
+        expression.addParameter(((Expressible) highPriorityTasks).toExpression(factory));
+      } else {
+        throw new IOException("The SchedulerStream contains a non-expressible TupleStream - it cannot be converted to an expression");
+      }
+
+      if (tasks instanceof Expressible) {
+        expression.addParameter(((Expressible) tasks).toExpression(factory));
+      } else {
+        throw new IOException("The SchedulerStream contains a non-expressible TupleStream - it cannot be converted to an expression");
+      }
+    }
+
+    return expression;
+  }
+
+  @Override
+  public Explanation toExplanation(StreamFactory factory) throws IOException {
+
+    return new StreamExplanation(getStreamNodeId().toString())
+        .withChildren(new Explanation[]{
+            highPriorityTasks.toExplanation(factory), tasks.toExplanation(factory)
+        })
+        .withFunctionName(factory.getFunctionName(this.getClass()))
+        .withImplementingClass(this.getClass().getName())
+        .withExpressionType(ExpressionType.STREAM_DECORATOR)
+        .withExpression(toExpression(factory, false).toString());
+  }
+
+  public void setStreamContext(StreamContext streamContext) {
+    this.highPriorityTasks.setStreamContext(streamContext);
+    tasks.setStreamContext(streamContext);
+  }
+
+  public List<TupleStream> children() {
+    List<TupleStream> l =  new ArrayList();
+    l.add(highPriorityTasks);
+    l.add(tasks);
+    return l;
+  }
+
+  public void open() throws IOException {
+    highPriorityTasks.open();
+    Tuple tuple = highPriorityTasks.read();
+    if(tuple.EOF) {
+      highPriorityTasks.close();
+      tasks.open();
+      currentStream = tasks;
+    } else {
+      highPriorityTasks.pushBack(tuple);
+      currentStream = highPriorityTasks;
+    }
+  }
+
+  public void close() throws IOException {
+      currentStream.close();
+  }
+
+  public Tuple read() throws IOException {
+    return currentStream.read();
+  }
+
+  public StreamComparator getStreamSort(){
+    return null;
+  }
+
+  public int getCost() {
+    return 0;
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0999f677/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/SchedulerStream.java
----------------------------------------------------------------------
diff --git a/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/SchedulerStream.java b/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/SchedulerStream.java
deleted file mode 100644
index f8506b9..0000000
--- a/solr/solrj/src/java/org/apache/solr/client/solrj/io/stream/SchedulerStream.java
+++ /dev/null
@@ -1,161 +0,0 @@
-/*
- * 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.stream;
-
-import java.io.IOException;
-import java.lang.invoke.MethodHandles;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Locale;
-
-import org.apache.solr.client.solrj.io.Tuple;
-import org.apache.solr.client.solrj.io.comp.StreamComparator;
-import org.apache.solr.client.solrj.io.stream.expr.Explanation;
-import org.apache.solr.client.solrj.io.stream.expr.Explanation.ExpressionType;
-import org.apache.solr.client.solrj.io.stream.expr.Expressible;
-import org.apache.solr.client.solrj.io.stream.expr.StreamExplanation;
-import org.apache.solr.client.solrj.io.stream.expr.StreamExpression;
-import org.apache.solr.client.solrj.io.stream.expr.StreamFactory;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * The scheduler wraps two topics that represent high priority and low priority task queues.
- * Each time the scheduler is called it will check to see if there are any high priority tasks in the queue. If there
- * are high priority tasks, then the high priority queue will be read until it returns the EOF Tuple.
- *
- * If there are no tasks in the high priority queue, then the lower priority task queue will be opened and read until the EOF Tuple is
- * returned.
- *
- * The scheduler is designed to be wrapped by the executor function and a daemon function can be used to call the executor iteratively.
- **/
-
-public class SchedulerStream extends TupleStream implements Expressible {
-
-  private static final Logger logger = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass());
-
-  private PushBackStream highPriorityTasks;
-  private PushBackStream tasks;
-  private TupleStream currentStream;
-
-  public SchedulerStream(StreamExpression expression, StreamFactory factory) throws IOException {
-    // grab all parameters out
-    List<StreamExpression> streamExpressions = factory.getExpressionOperandsRepresentingTypes(expression, Expressible.class, TupleStream.class);
-
-
-    if(2 != streamExpressions.size()){
-      throw new IOException(String.format(Locale.ROOT,"Invalid expression %s - expecting a single stream but found %d",expression, streamExpressions.size()));
-    }
-
-    TupleStream stream1 = factory.constructStream(streamExpressions.get(0));
-    TupleStream stream2 = factory.constructStream(streamExpressions.get(1));
-
-    if(!(stream1 instanceof TopicStream) || !(stream2 instanceof TopicStream)) {
-      throw new IOException("The scheduler expects both stream parameters to be topics.");
-    }
-
-    init(new PushBackStream(stream1), new PushBackStream(stream2));
-  }
-
-  private void init(PushBackStream stream1, PushBackStream stream2) throws IOException{
-    this.highPriorityTasks = stream1;
-    this.tasks = stream2;
-  }
-
-  @Override
-  public StreamExpression toExpression(StreamFactory factory) throws IOException {
-    return toExpression(factory, true);
-  }
-
-  private StreamExpression toExpression(StreamFactory factory, boolean includeStreams) throws IOException {
-
-    // function name
-    StreamExpression expression = new StreamExpression(factory.getFunctionName(this.getClass()));
-
-    // stream
-    if(includeStreams) {
-      if (highPriorityTasks instanceof Expressible) {
-        expression.addParameter(((Expressible) highPriorityTasks).toExpression(factory));
-      } else {
-        throw new IOException("The SchedulerStream contains a non-expressible TupleStream - it cannot be converted to an expression");
-      }
-
-      if (tasks instanceof Expressible) {
-        expression.addParameter(((Expressible) tasks).toExpression(factory));
-      } else {
-        throw new IOException("The SchedulerStream contains a non-expressible TupleStream - it cannot be converted to an expression");
-      }
-    }
-
-    return expression;
-  }
-
-  @Override
-  public Explanation toExplanation(StreamFactory factory) throws IOException {
-
-    return new StreamExplanation(getStreamNodeId().toString())
-        .withChildren(new Explanation[]{
-            highPriorityTasks.toExplanation(factory), tasks.toExplanation(factory)
-        })
-        .withFunctionName(factory.getFunctionName(this.getClass()))
-        .withImplementingClass(this.getClass().getName())
-        .withExpressionType(ExpressionType.STREAM_DECORATOR)
-        .withExpression(toExpression(factory, false).toString());
-  }
-
-  public void setStreamContext(StreamContext streamContext) {
-    this.highPriorityTasks.setStreamContext(streamContext);
-    tasks.setStreamContext(streamContext);
-  }
-
-  public List<TupleStream> children() {
-    List<TupleStream> l =  new ArrayList();
-    l.add(highPriorityTasks);
-    l.add(tasks);
-    return l;
-  }
-
-  public void open() throws IOException {
-    highPriorityTasks.open();
-    Tuple tuple = highPriorityTasks.read();
-    if(tuple.EOF) {
-      highPriorityTasks.close();
-      tasks.open();
-      currentStream = tasks;
-    } else {
-      highPriorityTasks.pushBack(tuple);
-      currentStream = highPriorityTasks;
-    }
-  }
-
-  public void close() throws IOException {
-      currentStream.close();
-  }
-
-  public Tuple read() throws IOException {
-    return currentStream.read();
-  }
-
-  public StreamComparator getStreamSort(){
-    return null;
-  }
-
-  public int getCost() {
-    return 0;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/0999f677/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 936d42f..1316af4 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
@@ -2826,7 +2826,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
   }
 
   @Test
-  public void testSchedulerStream() throws Exception {
+  public void testPriorityStream() throws Exception {
     Assume.assumeTrue(!useAlias);
 
     new UpdateRequest()
@@ -2845,7 +2845,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
     StreamFactory factory = new StreamFactory()
         .withCollectionZkHost("collection1", cluster.getZkServer().getZkAddress())
         .withFunctionName("topic", TopicStream.class)
-        .withFunctionName("schedule", SchedulerStream.class);
+        .withFunctionName("priority", PriorityStream.class);
 
     StreamExpression expression;
     TupleStream stream;
@@ -2856,7 +2856,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
     try {
       FieldComparator comp = new FieldComparator("a_i", ComparatorOrder.ASCENDING);
 
-      expression = StreamExpressionParser.parse("schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
+      expression = StreamExpressionParser.parse("priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0))");
       stream = factory.constructStream(expression);
       StreamContext context = new StreamContext();
@@ -2870,7 +2870,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
       assertEquals(tuples.size(), 4);
       assertOrder(tuples, 5, 6, 7, 8);
 
-      expression = StreamExpressionParser.parse("schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
+      expression = StreamExpressionParser.parse("priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0))");
       stream = factory.constructStream(expression);
       context = new StreamContext();
@@ -2883,7 +2883,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
       assertEquals(tuples.size(), 6);
       assertOrder(tuples, 0, 1, 2, 3, 4, 9);
 
-      expression = StreamExpressionParser.parse("schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
+      expression = StreamExpressionParser.parse("priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0))");
       stream = factory.constructStream(expression);
       context = new StreamContext();
@@ -2900,7 +2900,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
   }
 
   @Test
-  public void testParallelSchedulerStream() throws Exception {
+  public void testParallelPriorityStream() throws Exception {
     Assume.assumeTrue(!useAlias);
 
     new UpdateRequest()
@@ -2920,7 +2920,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
         .withCollectionZkHost("collection1", cluster.getZkServer().getZkAddress())
         .withFunctionName("topic", TopicStream.class)
         .withFunctionName("parallel", ParallelStream.class)
-        .withFunctionName("schedule", SchedulerStream.class);
+        .withFunctionName("priority", PriorityStream.class);
 
     StreamExpression expression;
     TupleStream stream;
@@ -2931,7 +2931,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
     try {
       FieldComparator comp = new FieldComparator("a_i", ComparatorOrder.ASCENDING);
 
-      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
+      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0, partitionKeys=id)))");
       stream = factory.constructStream(expression);
       StreamContext context = new StreamContext();
@@ -2945,7 +2945,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
       assertEquals(tuples.size(), 4);
       assertOrder(tuples, 5, 6, 7, 8);
 
-      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
+      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0, partitionKeys=id)))");
       stream = factory.constructStream(expression);
       context = new StreamContext();
@@ -2958,7 +2958,7 @@ public class StreamExpressionTest extends SolrCloudTestCase {
       assertEquals(tuples.size(), 6);
       assertOrder(tuples, 0, 1, 2, 3, 4, 9);
 
-      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", schedule(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
+      expression = StreamExpressionParser.parse("parallel(collection1, workers=2, sort=\"_version_ asc\", priority(topic(collection1, collection1, q=\"a_s:hello\", fl=\"id,a_i\", id=1000000, initialCheckpoint=0, partitionKeys=id)," +
           "topic(collection1, collection1, q=\"a_s:hello1\", fl=\"id,a_i\", id=2000000, initialCheckpoint=0, partitionKeys=id)))");
       stream = factory.constructStream(expression);
       context = new StreamContext();