You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucene.apache.org by mi...@apache.org on 2015/09/02 15:06:22 UTC

svn commit: r1700800 [5/24] - in /lucene/dev/branches/lucene6699: ./ dev-tools/ dev-tools/eclipse/ dev-tools/idea/.idea/ dev-tools/scripts/ lucene/ lucene/analysis/ lucene/analysis/common/ lucene/analysis/common/src/java/org/apache/lucene/analysis/ar/ ...

Modified: lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/highlight/WeightedSpanTermExtractor.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/highlight/WeightedSpanTermExtractor.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/highlight/WeightedSpanTermExtractor.java (original)
+++ lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/highlight/WeightedSpanTermExtractor.java Wed Sep  2 13:06:13 2015
@@ -180,7 +180,7 @@ public class WeightedSpanTermExtractor {
           }
         }
 
-        @SuppressWarnings("unchecked")
+        @SuppressWarnings({"unchecked","rawtypes"})
         final List<SpanQuery>[] disjunctLists = new List[maxPosition + 1];
         int distinctPositions = 0;
 

Modified: lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFieldFragList.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFieldFragList.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFieldFragList.java (original)
+++ lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFieldFragList.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.search.vectorhighlight;
 
-/**
+/*
  * 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.

Modified: lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilder.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilder.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilder.java (original)
+++ lucene/dev/branches/lucene6699/lucene/highlighter/src/java/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilder.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.search.vectorhighlight;
 
-/**
+/*
  * 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.

Modified: lucene/dev/branches/lucene6699/lucene/highlighter/src/test/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilderTest.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/highlighter/src/test/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilderTest.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/highlighter/src/test/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilderTest.java (original)
+++ lucene/dev/branches/lucene6699/lucene/highlighter/src/test/org/apache/lucene/search/vectorhighlight/WeightedFragListBuilderTest.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.search.vectorhighlight;
 
-/**
+/*
  * 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.

Modified: lucene/dev/branches/lucene6699/lucene/ivy-settings.xml
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/ivy-settings.xml?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/ivy-settings.xml (original)
+++ lucene/dev/branches/lucene6699/lucene/ivy-settings.xml Wed Sep  2 13:06:13 2015
@@ -28,7 +28,7 @@
   <include url="${ivy.default.settings.dir}/ivysettings-local.xml"/>
   <include url="${ivy.default.settings.dir}/ivysettings-main-chain.xml"/>
 
-  <caches lockStrategy="artifact-lock" resolutionCacheDir="${ivy.resolution-cache.dir}" /> 
+  <caches lockStrategy="${ivy.lock-strategy}" resolutionCacheDir="${ivy.resolution-cache.dir}" /> 
 
   <resolvers>
     <ibiblio name="sonatype-releases" root="https://oss.sonatype.org/content/repositories/releases" m2compatible="true" />
@@ -41,16 +41,12 @@
     <!-- you might need to tweak this from china so it works -->
     <ibiblio name="working-chinese-mirror" root="http://uk.maven.org/maven2" m2compatible="true" />
 
-    <ibiblio name="rr-snapshot" root="https://oss.sonatype.org/content/repositories/comcarrotsearch-1039" m2compatible="true" />
-
-    <!--
     <filesystem name="local-maven-2" m2compatible="true" local="true">
       <artifact
           pattern="${local-maven2-dir}/[organisation]/[module]/[revision]/[module]-[revision].[ext]" />
       <ivy
           pattern="${local-maven2-dir}/[organisation]/[module]/[revision]/[module]-[revision].pom" />
     </filesystem>
-    -->
 
     <chain name="default" returnFirst="true" checkmodified="true" changingPattern=".*SNAPSHOT">
       <resolver ref="local"/>
@@ -59,7 +55,6 @@
       <resolver ref="maven.restlet.org" />
       <resolver ref="sonatype-releases" />
       <resolver ref="releases.cloudera.com"/>
-      <resolver ref="rr-snapshot"/>
       <!-- <resolver ref="svnkit-releases" /> -->
       <resolver ref="working-chinese-mirror" />
     </chain>

Modified: lucene/dev/branches/lucene6699/lucene/ivy-versions.properties
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/ivy-versions.properties?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/ivy-versions.properties (original)
+++ lucene/dev/branches/lucene6699/lucene/ivy-versions.properties Wed Sep  2 13:06:13 2015
@@ -11,7 +11,7 @@ com.carrotsearch.randomizedtesting.versi
 /com.carrotsearch.randomizedtesting/junit4-ant = ${com.carrotsearch.randomizedtesting.version}
 /com.carrotsearch.randomizedtesting/randomizedtesting-runner = ${com.carrotsearch.randomizedtesting.version}
 
-/com.carrotsearch/hppc = 0.5.2
+/com.carrotsearch/hppc = 0.7.1
 
 com.codahale.metrics.version = 3.0.1
 /com.codahale.metrics/metrics-core = ${com.codahale.metrics.version}
@@ -211,10 +211,12 @@ org.bouncycastle.version = 1.45
 /org.bouncycastle/bcmail-jdk15 = ${org.bouncycastle.version}
 /org.bouncycastle/bcprov-jdk15 = ${org.bouncycastle.version}
 
-/org.carrot2.attributes/attributes-binder = 1.2.1
-/org.carrot2/carrot2-mini = 3.9.0
+/org.carrot2.attributes/attributes-binder = 1.2.3
+/org.carrot2.shaded/carrot2-guava = 18.0
 
-org.carrot2.morfologik.version = 1.7.1
+/org.carrot2/carrot2-mini = 3.10.3
+
+org.carrot2.morfologik.version = 1.10.0
 /org.carrot2/morfologik-fsa = ${org.carrot2.morfologik.version}
 /org.carrot2/morfologik-polish = ${org.carrot2.morfologik.version}
 /org.carrot2/morfologik-stemming = ${org.carrot2.morfologik.version}
@@ -230,7 +232,7 @@ org.codehaus.jackson.version = 1.9.13
 /org.codehaus.woodstox/woodstox-core-asl = 4.4.1
 /org.easymock/easymock = 3.0
 
-org.eclipse.jetty.version = 9.2.11.v20150529
+org.eclipse.jetty.version = 9.2.13.v20150730
 /org.eclipse.jetty/jetty-continuation = ${org.eclipse.jetty.version}
 /org.eclipse.jetty/jetty-deploy = ${org.eclipse.jetty.version}
 /org.eclipse.jetty/jetty-http = ${org.eclipse.jetty.version}
@@ -286,7 +288,7 @@ org.restlet.jee.version = 2.3.0
 /org.restlet.jee/org.restlet = ${org.restlet.jee.version}
 /org.restlet.jee/org.restlet.ext.servlet = ${org.restlet.jee.version}
 
-/org.simpleframework/simple-xml = 2.7
+/org.simpleframework/simple-xml = 2.7.1
 
 org.slf4j.version = 1.7.7
 /org.slf4j/jcl-over-slf4j = ${org.slf4j.version}

Modified: lucene/dev/branches/lucene6699/lucene/join/src/test/org/apache/lucene/search/join/TestBlockJoin.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/join/src/test/org/apache/lucene/search/join/TestBlockJoin.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/join/src/test/org/apache/lucene/search/join/TestBlockJoin.java (original)
+++ lucene/dev/branches/lucene6699/lucene/join/src/test/org/apache/lucene/search/join/TestBlockJoin.java Wed Sep  2 13:06:13 2015
@@ -1221,7 +1221,7 @@ public class TestBlockJoin extends Lucen
     s.search(childJoinQuery, c);
 
     //Get all child documents within groups
-    @SuppressWarnings({"unchecked"})
+    @SuppressWarnings({"unchecked","rawtypes"})
     TopGroups<Integer>[] getTopGroupsResults = new TopGroups[2];
     getTopGroupsResults[0] = c.getTopGroups(childJoinQuery, null, 0, 10, 0, true);
     getTopGroupsResults[1] = c.getTopGroupsWithAllChildDocs(childJoinQuery, null, 0, 0, true);
@@ -1634,5 +1634,103 @@ public class TestBlockJoin extends Lucen
     r.close();
     dir.close();
   }
+  
+  public void testToChildInitialAdvanceParentButNoKids() throws Exception {
+    
+    final Directory dir = newDirectory();
+    final RandomIndexWriter w = new RandomIndexWriter(random(), dir);
+
+    // degenerate case: first doc has no children
+    w.addDocument(makeResume("first", "nokids"));
+    w.addDocuments(Arrays.asList(makeJob("job", 42), makeResume("second", "haskid")));
+
+    // single segment
+    w.forceMerge(1);
+
+    final IndexReader r = w.getReader();
+    final IndexSearcher s = newSearcher(r);
+    w.close();
+
+    BitSetProducer parentFilter = new QueryBitSetProducer(new TermQuery(new Term("docType", "resume")));
+    Query parentQuery = new TermQuery(new Term("docType", "resume"));
 
+    ToChildBlockJoinQuery parentJoinQuery = new ToChildBlockJoinQuery(parentQuery, parentFilter);
+
+    Weight weight = s.createNormalizedWeight(parentJoinQuery, random().nextBoolean());
+    DocIdSetIterator advancingScorer = weight.scorer(s.getIndexReader().leaves().get(0));
+    DocIdSetIterator nextDocScorer = weight.scorer(s.getIndexReader().leaves().get(0));
+
+    final int firstKid = nextDocScorer.nextDoc();
+    assertTrue("firstKid not found", DocIdSetIterator.NO_MORE_DOCS != firstKid);
+    assertEquals(firstKid, advancingScorer.advance(0));
+    
+    r.close();
+    dir.close();
+  }
+
+  public void testMultiChildQueriesOfDiffParentLevels() throws Exception {
+    
+    final Directory dir = newDirectory();
+    final RandomIndexWriter w = new RandomIndexWriter(random(), dir);
+
+    // randomly generate resume->jobs[]->qualifications[]
+    final int numResumes = atLeast(100);
+    for (int r = 0; r < numResumes; r++) {
+      final List<Document> docs = new ArrayList<>();
+      
+      final int rv = TestUtil.nextInt(random(), 1, 10);
+      final int numJobs = atLeast(10);
+      for (int j = 0; j < numJobs; j++) {
+        final int jv = TestUtil.nextInt(random(), -10, -1); // neg so no overlap with q (both used for "year")
+
+        final int numQualifications = atLeast(10);
+        for (int q = 0; q < numQualifications; q++) {
+          docs.add(makeQualification("q" + q + "_rv" + rv + "_jv" + jv, q));
+        }
+        docs.add(makeJob("j" + j, jv));
+      }
+      docs.add(makeResume("r" + r, "rv"+rv));
+      w.addDocuments(docs);
+    }
+
+    final IndexReader r = w.getReader();
+    final IndexSearcher s = newSearcher(r);
+    w.close();
+
+    BitSetProducer resumeFilter = new QueryBitSetProducer(new TermQuery(new Term("docType", "resume")));
+    // anything with a skill is a job
+    BitSetProducer jobFilter = new QueryBitSetProducer(new PrefixQuery(new Term("skill", "")));
+
+
+    final int numQueryIters = atLeast(1);
+    for (int i = 0; i < numQueryIters; i++) {
+      final int qjv = TestUtil.nextInt(random(), -10, -1);
+      final int qrv = TestUtil.nextInt(random(), 1, 10);
+      
+      Query resumeQuery = new ToChildBlockJoinQuery(new TermQuery(new Term("country","rv" + qrv)),
+                                                    resumeFilter);
+      
+      Query jobQuery = new ToChildBlockJoinQuery(NumericRangeQuery.newIntRange("year", qjv, qjv, true, true),
+                                                 jobFilter);
+      
+      BooleanQuery.Builder fullQuery = new BooleanQuery.Builder();
+      fullQuery.add(new BooleanClause(jobQuery, Occur.MUST));
+      fullQuery.add(new BooleanClause(resumeQuery, Occur.MUST));
+      
+      TopDocs hits = s.search(fullQuery.build(), 100); // NOTE: totally possible that we'll get no matches
+      
+      for (ScoreDoc sd : hits.scoreDocs) {
+        // since we're looking for children of jobs, all results must be qualifications
+        String q = r.document(sd.doc).get("qualification");
+        assertNotNull(sd.doc + " has no qualification", q);
+        assertTrue(q + " MUST contain jv" + qjv, q.contains("jv"+qjv));
+        assertTrue(q + " MUST contain rv" + qrv, q.contains("rv"+qrv));
+      }
+    }
+    
+    r.close();
+    dir.close();
+  }
+
+  
 }

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/document/LazyDocument.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/document/LazyDocument.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/document/LazyDocument.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/document/LazyDocument.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.document;
 
-/**
+/*
  * Copyright 2004 The Apache Software Foundation
  *
  * Licensed under the Apache License, Version 2.0 (the "License");

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/misc/IndexMergeTool.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/misc/IndexMergeTool.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/misc/IndexMergeTool.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/misc/IndexMergeTool.java Wed Sep  2 13:06:13 2015
@@ -1,20 +1,20 @@
 package org.apache.lucene.misc;
 
-/**
-  * Copyright 2005 The Apache Software Foundation
-  *
-  * Licensed 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.
-  */
+/*
+ * Copyright 2005 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
 
 import org.apache.lucene.index.IndexWriter;
 import org.apache.lucene.index.IndexWriterConfig;

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/search/BlockJoinComparatorSource.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/search/BlockJoinComparatorSource.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/search/BlockJoinComparatorSource.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/search/BlockJoinComparatorSource.java Wed Sep  2 13:06:13 2015
@@ -68,6 +68,7 @@ public class BlockJoinComparatorSource e
   }
 
   @Override
+  @SuppressWarnings({"unchecked", "rawtypes"})
   public FieldComparator<Integer> newComparator(String fieldname, int numHits, int sortPos, boolean reversed) throws IOException {
     // we keep parallel slots: the parent ids and the child ids
     final int parentSlots[] = new int[numHits];

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/uninverting/FieldCacheSanityChecker.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/uninverting/FieldCacheSanityChecker.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/uninverting/FieldCacheSanityChecker.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/java/org/apache/lucene/uninverting/FieldCacheSanityChecker.java Wed Sep  2 13:06:13 2015
@@ -1,5 +1,5 @@
 package org.apache.lucene.uninverting;
-/**
+/*
  * Copyright 2009 The Apache Software Foundation
  *
  * Licensed under the Apache License, Version 2.0 (the "License");

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCache.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCache.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCache.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCache.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.uninverting;
 
-/**
+/*
  * Copyright 2004 The Apache Software Foundation
  *
  * Licensed under the Apache License, Version 2.0 (the "License");

Modified: lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCacheSanityChecker.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCacheSanityChecker.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCacheSanityChecker.java (original)
+++ lucene/dev/branches/lucene6699/lucene/misc/src/test/org/apache/lucene/uninverting/TestFieldCacheSanityChecker.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.uninverting;
 
-/**
+/*
  * Copyright 2009 The Apache Software Foundation
  *
  * Licensed under the Apache License, Version 2.0 (the "License");

Modified: lucene/dev/branches/lucene6699/lucene/module-build.xml
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/module-build.xml?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/module-build.xml (original)
+++ lucene/dev/branches/lucene6699/lucene/module-build.xml Wed Sep  2 13:06:13 2015
@@ -63,7 +63,7 @@
   <target name="javadocs" depends="compile-core,javadocs-lucene-core,check-javadocs-uptodate"
                           unless="javadocs-uptodate-${name}">
     <invoke-module-javadoc/>
-  </target>	
+  </target>
 
   <macrodef name="invoke-module-javadoc">
     <!-- additional links for dependencies to other modules -->
@@ -74,7 +74,7 @@
       <mkdir dir="${javadoc.dir}/${name}"/>
       <invoke-javadoc
          destdir="${javadoc.dir}/${name}"
-       	 title="${Name} ${version} ${name} API"
+         title="${Name} ${version} ${name} API"
          linksource="@{linksource}">
          <sources>
            <link href="../core/"/>
@@ -130,7 +130,7 @@
     </ant>
     <property name="queryparser-javadocs.uptodate" value="true"/>
   </target>
-	
+  
   <property name="join.jar" value="${common.dir}/build/join/lucene-join-${version}.jar"/>
   <target name="check-join-uptodate" unless="join.uptodate">
     <module-uptodate name="join" jarfile="${join.jar}" property="join.uptodate"/>
@@ -138,9 +138,9 @@
   <target name="jar-join" unless="join.uptodate" depends="check-join-uptodate">
     <ant dir="${common.dir}/join" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
-	</ant>
-	<property name="join.uptodate" value="true"/>
-  </target>	
+    </ant>
+    <property name="join.uptodate" value="true"/>
+  </target>  
   
   <property name="join-javadoc.jar" value="${common.dir}/build/join/lucene-join-${version}-javadoc.jar"/>
   <target name="check-join-javadocs-uptodate" unless="join-javadocs.uptodate">
@@ -180,7 +180,7 @@
     <module-uptodate name="queries" jarfile="${queries.jar}" property="queries.uptodate"/>
   </target>
   <target name="jar-queries" unless="queries.uptodate" depends="check-queries-uptodate">
-  	<ant dir="${common.dir}/queries" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/queries" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="queries.uptodate" value="true"/>
@@ -268,7 +268,7 @@
     <module-uptodate name="analysis/icu" jarfile="${analyzers-icu.jar}" property="analyzers-icu.uptodate"/>
   </target>
   <target name="jar-analyzers-icu" unless="analyzers-icu.uptodate" depends="check-analyzers-icu-uptodate">
-  	<ant dir="${common.dir}/analysis/icu" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/analysis/icu" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="analyzers-icu.uptodate" value="true"/>
@@ -290,7 +290,7 @@
     <module-uptodate name="analysis/phonetic" jarfile="${analyzers-phonetic.jar}" property="analyzers-phonetic.uptodate"/>
   </target>
   <target name="jar-analyzers-phonetic" unless="analyzers-phonetic.uptodate" depends="check-analyzers-phonetic-uptodate">
-  	<ant dir="${common.dir}/analysis/phonetic" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/analysis/phonetic" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
   </target>
@@ -311,7 +311,7 @@
     <module-uptodate name="analysis/smartcn" jarfile="${analyzers-smartcn.jar}" property="analyzers-smartcn.uptodate"/>
   </target>
   <target name="jar-analyzers-smartcn" unless="analyzers-smartcn.uptodate" depends="check-analyzers-smartcn-uptodate">
-  	<ant dir="${common.dir}/analysis/smartcn" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/analysis/smartcn" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="analyzers-smartcn.uptodate" value="true"/>
@@ -333,7 +333,7 @@
     <module-uptodate name="analysis/stempel" jarfile="${analyzers-stempel.jar}" property="analyzers-stempel.uptodate"/>
   </target>
   <target name="jar-analyzers-stempel" unless="analyzers-stempel.uptodate" depends="check-analyzers-stempel-uptodate">
-  	<ant dir="${common.dir}/analysis/stempel" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/analysis/stempel" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="analyzers-stempel.uptodate" value="true"/>
@@ -355,7 +355,7 @@
     <module-uptodate name="analysis/kuromoji" jarfile="${analyzers-kuromoji.jar}" property="analyzers-kuromoji.uptodate"/>
   </target>
   <target name="jar-analyzers-kuromoji" unless="analyzers-kuromoji.uptodate" depends="check-analyzers-kuromoji-uptodate">
-  	<ant dir="${common.dir}/analysis/kuromoji" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/analysis/kuromoji" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="analyzers-kuromoji.uptodate" value="true"/>
@@ -491,7 +491,7 @@
     <module-uptodate name="grouping" jarfile="${grouping.jar}" property="grouping.uptodate"/>
   </target>
   <target name="jar-grouping" unless="grouping.uptodate" depends="check-grouping-uptodate">
-  	<ant dir="${common.dir}/grouping" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/grouping" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="grouping.uptodate" value="true"/>
@@ -557,7 +557,7 @@
     <module-uptodate name="misc" jarfile="${misc.jar}" property="misc.uptodate"/>
   </target>
   <target name="jar-misc" unless="misc.uptodate" depends="check-misc-uptodate">
-  	<ant dir="${common.dir}/misc" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/misc" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="misc.uptodate" value="true"/>
@@ -579,7 +579,7 @@
     <module-uptodate name="sandbox" jarfile="${sandbox.jar}" property="sandbox.uptodate"/>
   </target>
   <target name="jar-sandbox" unless="sandbox.uptodate" depends="check-sandbox-uptodate">
-  	<ant dir="${common.dir}/sandbox" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/sandbox" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="sandbox.uptodate" value="true"/>
@@ -601,7 +601,7 @@
     <module-uptodate name="spatial3d" jarfile="${spatial3d.jar}" property="spatial3d.uptodate"/>
   </target>
   <target name="jar-spatial3d" unless="spatial3d.uptodate" depends="check-spatial3d-uptodate">
-  	<ant dir="${common.dir}/spatial3d" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/spatial3d" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="spatial3d.uptodate" value="true"/>
@@ -623,7 +623,7 @@
     <module-uptodate name="spatial" jarfile="${spatial.jar}" property="spatial.uptodate"/>
   </target>
   <target name="jar-spatial" unless="spatial.uptodate" depends="check-spatial-uptodate">
-  	<ant dir="${common.dir}/spatial" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/spatial" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="spatial.uptodate" value="true"/>
@@ -645,7 +645,7 @@
     <module-uptodate name="suggest" jarfile="${suggest.jar}" property="suggest.uptodate"/>
   </target>
   <target name="jar-suggest" unless="suggest.uptodate" depends="check-suggest-uptodate">
-  	<ant dir="${common.dir}/suggest" target="jar-core" inheritAll="false">
+    <ant dir="${common.dir}/suggest" target="jar-core" inheritAll="false">
       <propertyset refid="uptodate.and.compiled.properties"/>
     </ant>
     <property name="suggest.uptodate" value="true"/>

Modified: lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/BoostingQuery.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/BoostingQuery.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/BoostingQuery.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/BoostingQuery.java Wed Sep  2 13:06:13 2015
@@ -59,8 +59,8 @@ public class BoostingQuery extends Query
       if (needsScores == false) {
         return match.createWeight(searcher, needsScores);
       }
-      final Weight matchWeight = match.createWeight(searcher, needsScores);
-      final Weight contextWeight = context.createWeight(searcher, false);
+      final Weight matchWeight = searcher.createWeight(match, needsScores);
+      final Weight contextWeight = searcher.createWeight(context, false);
       return new Weight(this) {
 
         @Override

Modified: lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/function/BoostedQuery.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/function/BoostedQuery.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/function/BoostedQuery.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/function/BoostedQuery.java Wed Sep  2 13:06:13 2015
@@ -32,7 +32,6 @@ import org.apache.lucene.search.IndexSea
 import org.apache.lucene.search.Query;
 import org.apache.lucene.search.Scorer;
 import org.apache.lucene.search.Weight;
-import org.apache.lucene.util.Bits;
 import org.apache.lucene.util.ToStringUtils;
 
 /**
@@ -74,7 +73,7 @@ public class BoostedQuery extends Query
     public BoostedWeight(IndexSearcher searcher, boolean needsScores) throws IOException {
       super(BoostedQuery.this);
       this.searcher = searcher;
-      this.qWeight = q.createWeight(searcher, needsScores);
+      this.qWeight = searcher.createWeight(q, needsScores);
       this.fcontext = ValueSource.newContext(searcher);
       boostVal.createWeight(fcontext,searcher);
     }

Modified: lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/mlt/MoreLikeThis.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/mlt/MoreLikeThis.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/mlt/MoreLikeThis.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queries/src/java/org/apache/lucene/queries/mlt/MoreLikeThis.java Wed Sep  2 13:06:13 2015
@@ -1,6 +1,6 @@
 package org.apache.lucene.queries.mlt;
 
-/**
+/*
  * Copyright 2004-2005 The Apache Software Foundation.
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
@@ -751,7 +751,7 @@ public final class MoreLikeThis {
 
   private PriorityQueue<ScoreTerm> retrieveTerms(Map<String, Collection<Object>> fields) throws 
       IOException {
-    HashMap<String,Int> termFreqMap = new HashMap();
+    HashMap<String,Int> termFreqMap = new HashMap<>();
     for (String fieldName : fieldNames) {
       for (String field : fields.keySet()) {
         Collection<Object> fieldValues = fields.get(field);

Modified: lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestDocValuesFieldSources.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestDocValuesFieldSources.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestDocValuesFieldSources.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestDocValuesFieldSources.java Wed Sep  2 13:06:13 2015
@@ -44,6 +44,7 @@ import com.carrotsearch.randomizedtestin
 
 public class TestDocValuesFieldSources extends LuceneTestCase {
 
+  @SuppressWarnings("fallthrough")
   public void test(DocValuesType type) throws IOException {
     Directory d = newDirectory();
     IndexWriterConfig iwConfig = newIndexWriterConfig(new MockAnalyzer(random()));
@@ -126,6 +127,7 @@ public class TestDocValuesFieldSources e
           case SORTED:
             values.ordVal(i); // no exception
             assertTrue(values.numOrd() >= 1);
+            // fall-through
           case BINARY:
             assertEquals(expected, values.objectVal(i));
             assertEquals(expected, values.strVal(i));

Modified: lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestLongNormValueSource.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestLongNormValueSource.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestLongNormValueSource.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queries/src/test/org/apache/lucene/queries/function/TestLongNormValueSource.java Wed Sep  2 13:06:13 2015
@@ -203,10 +203,10 @@ class PreciseDefaultSimilarity extends T
     return 1;
   }
 
-  /** Implemented as <code>log(numDocs/(docFreq+1)) + 1</code>. */
+  /** Implemented as <code>log(docCount/(docFreq+1)) + 1</code>. */
   @Override
-  public float idf(long docFreq, long numDocs) {
-    return (float)(Math.log(numDocs/(double)(docFreq+1)) + 1.0);
+  public float idf(long docFreq, long docCount) {
+    return (float)(Math.log(docCount/(double)(docFreq+1)) + 1.0);
   }
 
   /**

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/build.xml
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/build.xml?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/build.xml (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/build.xml Wed Sep  2 13:06:13 2015
@@ -49,10 +49,14 @@
       <replace token="StringBuffer" value="StringBuilder" encoding="UTF-8">
          <fileset dir="@{dir}" includes="ParseException.java TokenMgrError.java"/>
       </replace>
-      <!-- Remove debug stream (violates forbiddena-apis) -->
+      <!-- Remove debug stream (violates forbidden-apis) -->
       <replaceregexp match="/\*\* Debug.*debugStream\s*=\s*ds;\s*}" replace="" flags="s" encoding="UTF-8">
          <fileset dir="@{dir}" includes="*TokenManager.java"/>
       </replaceregexp>
+      <!-- Add warnings supression -->
+      <replaceregexp match="^\Qpublic class\E" replace="@SuppressWarnings(&quot;cast&quot;)${line.separator}\0" flags="m" encoding="UTF-8">
+         <fileset dir="@{dir}" includes="*TokenManager.java"/>
+      </replaceregexp>
     </sequential>
   </macrodef>
   
@@ -63,19 +67,19 @@
 
       <!-- Change the incorrect public ctors for QueryParser to be protected instead -->
       <replaceregexp file="src/java/org/apache/lucene/queryparser/classic/QueryParser.java"
-		     byline="true"
-		     match="public QueryParser\(CharStream "
-		     replace="protected QueryParser(CharStream "/>
+         byline="true"
+         match="public QueryParser\(CharStream "
+         replace="protected QueryParser(CharStream "/>
       <replaceregexp file="src/java/org/apache/lucene/queryparser/classic/QueryParser.java"
-		     byline="true"
-		     match="public QueryParser\(QueryParserTokenManager "
-		     replace="protected QueryParser(QueryParserTokenManager "/>
+         byline="true"
+         match="public QueryParser\(QueryParserTokenManager "
+         replace="protected QueryParser(QueryParserTokenManager "/>
       <generalReplaces dir="src/java/org/apache/lucene/queryparser/classic"/>
     </sequential>
   </target>
 
   <target name="javacc-surround" depends="resolve-javacc" description="generate surround query parser">
-  	<invoke-javacc target="src/java/org/apache/lucene/queryparser/surround/parser/QueryParser.jj"
+    <invoke-javacc target="src/java/org/apache/lucene/queryparser/surround/parser/QueryParser.jj"
                    outputDir="src/java/org/apache/lucene/queryparser/surround/parser"
     />
     <generalReplaces dir="src/java/org/apache/lucene/queryparser/surround/parser"/>

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneContribQuery.dtd.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneContribQuery.dtd.html?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneContribQuery.dtd.html (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneContribQuery.dtd.html Wed Sep  2 13:06:13 2015
@@ -27,20 +27,20 @@ Child of <a href='#BoostQuery'>BoostQuer
 </td></tr></table>
 <p>BooleanQuerys implement Boolean logic which controls how multiple Clauses should be interpreted.
 Some clauses may represent optional Query criteria while others represent mandatory criteria.</p><p><span class='inTextTitle'>Example:</span> <em>Find articles about banks, preferably talking about mergers but nothing to do with "sumitomo"</em>
-</p><pre>	          
+</p><pre>            
             &lt;BooleanQuery fieldName="contents"&gt;
-	             &lt;Clause occurs="should"&gt;
-		              &lt;TermQuery&gt;merger&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
-	             &lt;Clause occurs="mustnot"&gt;
-		              &lt;TermQuery&gt;sumitomo&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
-	             &lt;Clause occurs="must"&gt;
-		              &lt;TermQuery&gt;bank&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
+               &lt;Clause occurs="should"&gt;
+                  &lt;TermQuery&gt;merger&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
+               &lt;Clause occurs="mustnot"&gt;
+                  &lt;TermQuery&gt;sumitomo&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
+               &lt;Clause occurs="must"&gt;
+                  &lt;TermQuery&gt;bank&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
             &lt;/BooleanQuery&gt;
 
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;BooleanQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;BooleanQuery&gt;'s children</th></tr>
@@ -138,18 +138,18 @@ Bitsets at a cost of 1 bit per document
 Queries that are cached as filters obviously retain none of the scoring information associated with results - they retain just
 a Boolean yes/no record of which documents matched.</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about banks from the last 10 years - caching the commonly-used "last 10 year" filter as a BitSet in
 RAM to eliminate the cost of building this filter from disk for every query</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;bank&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                   &lt;CachedFilter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
                   &lt;/CachedFilter&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;CachedFilter&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;CachedFilter&gt;'s children</th></tr>
@@ -188,9 +188,9 @@ RAM to eliminate the cost of building th
 Child of <a href='#BoostQuery'>BoostQuery</a>, <a href='#Clause'>Clause</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#Query'>Query</a>
 </td></tr></table>
 <p>Passes content directly through to the standard LuceneQuery parser see "Lucene Query Syntax"</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about John Smith or John Doe using standard LuceneQuerySyntax</em>
-</p><pre>	          
+</p><pre>            
                &lt;UserQuery&gt;"John Smith" OR "John Doe"&lt;/UserQuery&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;UserQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;UserQuery&gt;'s attributes</th>
 </tr>
@@ -221,24 +221,24 @@ is a "mustNot" match (Lucene requires at
 <li> in a FilteredQuery where a Filter tag is effectively being
 used to select content rather than its usual role of filtering the results of a query.</li>
 </ol></p><p><span class='inTextTitle'>Example:</span> <em>Effectively use a Filter as a query </em>
-</p><pre>	          
+</p><pre>            
                &lt;FilteredQuery&gt;
                  &lt;Query&gt;
                     &lt;MatchAllDocsQuery/&gt;
                  &lt;/Query&gt;
                  &lt;Filter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19870409" upperTerm="19870412"/&gt;
-                 &lt;/Filter&gt;	
-               &lt;/FilteredQuery&gt;	         
-	       </pre><p></p><p class='emptyTagNote'>This element is always empty.</p><a name='TermQuery'></a>
+                 &lt;/Filter&gt;  
+               &lt;/FilteredQuery&gt;           
+         </pre><p></p><p class='emptyTagNote'>This element is always empty.</p><a name='TermQuery'></a>
 <br /><table class='elementTitle' summary="TermQuery"><tr><td class='leftElementTitle'>
 &lt;TermQuery&gt;</td><td class='rightElementTitle'>
 Child of <a href='#BoostQuery'>BoostQuery</a>, <a href='#Clause'>Clause</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#Query'>Query</a>
 </td></tr></table>
 <p>a single term query - no analysis is done of the child text</p><p><span class='inTextTitle'>Example:</span> <em>Match on a primary key</em>
-</p><pre>	          
+</p><pre>            
                &lt;TermQuery fieldName="primaryKey"&gt;13424&lt;/TermQuery&gt;
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;TermQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;TermQuery&gt;'s attributes</th>
 </tr>
@@ -282,9 +282,9 @@ Child text is analyzed using a field-spe
 Unlike UserQuery element, this does not parse any special characters to control fuzzy/phrase/boolean logic and as such is incapable
 of producing a Query parse error given any user input</p><p><span class='inTextTitle'>Example:</span> <em>Match on text from a database description (which may contain characters that
 are illegal characters in the standard Lucene Query syntax used in the UserQuery tag</em>
-</p><pre>	          
+</p><pre>            
                &lt;TermsQuery fieldName="description"&gt;Smith & Sons (Ltd) : incorporated 1982&lt;/TermsQuery&gt;
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;TermsQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;TermsQuery&gt;'s attributes</th>
 </tr>
@@ -319,16 +319,16 @@ Attribute of <a href='#TermsQuery'>Terms
 Child of <a href='#BoostQuery'>BoostQuery</a>, <a href='#Clause'>Clause</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#Query'>Query</a>
 </td></tr></table>
 <p>Runs a Query and filters results to only those query matches that also match the Filter element.</p><p><span class='inTextTitle'>Example:</span> <em>Find all documents about Lucene that have a status of "published"</em>
-</p><pre>	          
+</p><pre>            
                &lt;FilteredQuery&gt;
                  &lt;Query&gt;
                     &lt;UserQuery&gt;Lucene&lt;/UserQuery&gt;
                  &lt;/Query&gt;
                  &lt;Filter&gt;
                      &lt;TermsFilter fieldName="status"&gt;published&lt;/TermsFilter&gt;
-                 &lt;/Filter&gt;	
-               &lt;/FilteredQuery&gt;	         
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+                 &lt;/Filter&gt;  
+               &lt;/FilteredQuery&gt;           
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;FilteredQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;FilteredQuery&gt;'s children</th></tr>
@@ -409,16 +409,16 @@ Child of <a href='#FilteredQuery'>Filter
 Child of <a href='#Clause'>Clause</a>, <a href='#Filter'>Filter</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#ConstantScoreQuery'>ConstantScoreQuery</a>
 </td></tr></table>
 <p>Filter used to limit query results to documents matching a range of field values</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about banks from the last 10 years</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;bank&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;RangeFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;RangeFilter&gt;'s attributes</th>
 </tr>
@@ -458,9 +458,9 @@ Attribute of <a href='#RangeFilter'>Rang
 Child of <a href='#BoostQuery'>BoostQuery</a>, <a href='#Clause'>Clause</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#Query'>Query</a>
 </td></tr></table>
 <p>A Query that matches numeric values within a specified range.</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about people who are aged 20-25</em>
-</p><pre>	          
+</p><pre>            
             &lt;NumericRangeQuery fieldName="age" lowerTerm="20" upperTerm="25" /&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;NumericRangeQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;NumericRangeQuery&gt;'s attributes</th>
 </tr>
@@ -510,16 +510,16 @@ Attribute of <a href='#NumericRangeQuery
 Child of <a href='#Clause'>Clause</a>, <a href='#Filter'>Filter</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#ConstantScoreQuery'>ConstantScoreQuery</a>
 </td></tr></table>
 <p>A Filter that only accepts numeric values within a specified range</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about people who are aged 20-25</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;person&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                      &lt;NumericRangeFilter fieldName="age" lowerTerm="20" upperTerm="25"/&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;NumericRangeFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;NumericRangeFilter&gt;'s attributes</th>
 </tr>
@@ -570,19 +570,19 @@ Child of <a href='#BoostQuery'>BoostQuer
 </td></tr></table>
 <p>A single term used in a SpanQuery. These clauses are the building blocks for more complex "span" queries which test word proximity</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms close to each other about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;SpanTerm&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;SpanTerm&gt;'s attributes</th>
 </tr>
@@ -604,11 +604,11 @@ Child of <a href='#BoostQuery'>BoostQuer
 <p>A field-specific analyzer is used here to parse the child text provided in this tag. The SpanTerms produced are ORed in terms of Boolean logic</p><p><span class='inTextTitle'>Example:</span> <em>Use SpanOrTerms as a more convenient/succinct way of expressing multiple choices of SpanTerms. This example looks for reports
 using words describing a fatality near to references to miners</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOrTerms&gt;killed died death dead deaths&lt;/SpanOrTerms&gt;
-			&lt;SpanOrTerms&gt;miner mining miners&lt;/SpanOrTerms&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOrTerms&gt;killed died death dead deaths&lt;/SpanOrTerms&gt;
+      &lt;SpanOrTerms&gt;miner mining miners&lt;/SpanOrTerms&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;SpanOrTerms&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;SpanOrTerms&gt;'s attributes</th>
 </tr>
@@ -629,19 +629,19 @@ Child of <a href='#BoostQuery'>BoostQuer
 </td></tr></table>
 <p>Takes any number of child queries from the Span family</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms close to each other about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanOr&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanOr&gt;'s children</th></tr>
@@ -692,19 +692,19 @@ Attribute of <a href='#SpanNear'>SpanNea
 </td></tr></table>
 <p>defines the maximum distance between Span elements where distance is expressed as word number, not byte offset</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms within 8 words of each other talking about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><p><span class='inTextTitle'>Required</span></p><a name='SpanNear_inOrder'></a>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><p><span class='inTextTitle'>Required</span></p><a name='SpanNear_inOrder'></a>
 <br /><table class='attributeTitle' summary="inOrder"><tr><td class='leftAttributeTitle'>
 @inOrder</td><td class='rightAttributeTitle'>
 Attribute of <a href='#SpanNear'>SpanNear</a>
@@ -715,11 +715,11 @@ Attribute of <a href='#SpanNear'>SpanNea
 Child of <a href='#BoostQuery'>BoostQuery</a>, <a href='#Clause'>Clause</a>, <a href='#Include'>Include</a>, <a href='#CachedFilter'>CachedFilter</a>, <a href='#SpanOr'>SpanOr</a>, <a href='#SpanNear'>SpanNear</a>, <a href='#Exclude'>Exclude</a>, <a href='#Query'>Query</a>
 </td></tr></table>
 <p>Looks for a SpanQuery match occuring near the beginning of a document</p><p><span class='inTextTitle'>Example:</span> <em>Find letters where the first 50 words talk about a resignation:</em>
-</p><pre>	          
-	         &lt;SpanFirst end="50"&gt;
-	               &lt;SpanOrTerms fieldName="text"&gt;resigning resign leave&lt;/SpanOrTerms&gt;
-	         &lt;/SpanFirst&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+</p><pre>            
+           &lt;SpanFirst end="50"&gt;
+                 &lt;SpanOrTerms fieldName="text"&gt;resigning resign leave&lt;/SpanOrTerms&gt;
+           &lt;/SpanFirst&gt;
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanFirst&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanFirst&gt;'s children</th></tr>
@@ -761,16 +761,16 @@ Child of <a href='#BoostQuery'>BoostQuer
 </p><pre>
           &lt;SpanNot fieldName="text"&gt;
              &lt;Include&gt;
-                &lt;SpanNear slop="2" inOrder="true"&gt;		
+                &lt;SpanNear slop="2" inOrder="true"&gt;    
                      &lt;SpanTerm&gt;social&lt;/SpanTerm&gt;
                      &lt;SpanTerm&gt;services&lt;/SpanTerm&gt;
-                &lt;/SpanNear&gt;				
+                &lt;/SpanNear&gt;        
              &lt;/Include&gt;
              &lt;Exclude&gt;
                 &lt;SpanTerm&gt;public&lt;/SpanTerm&gt;
              &lt;/Exclude&gt;
           &lt;/SpanNot&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanNot&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanNot&gt;'s children</th></tr>
@@ -832,8 +832,8 @@ Child of <a href='#BoostQuery'>BoostQuer
 </p><pre>
      &lt;ConstantScoreQuery&gt;
            &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
-     &lt;/ConstantScoreQuery&gt;	
-	</pre><p></p><blockquote><table summary='element info'><tr>
+     &lt;/ConstantScoreQuery&gt;  
+  </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;ConstantScoreQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;ConstantScoreQuery&gt;'s children</th></tr>
@@ -869,13 +869,13 @@ Child of <a href='#BoostQuery'>BoostQuer
 Improves on FuzzyQuery by rewarding all fuzzy variants of a term with the same IDF rather than default fuzzy behaviour which ranks rarer
 variants (typically misspellings) more highly. This can be a useful default search mode for processing user input where the end user
 is not expected to know about the standard query operators for fuzzy, boolean or phrase logic found in UserQuery</p><p><span class='inTextTitle'>Example:</span> <em>Search for information about the Sumitomo bank, where the end user has mis-spelt the name</em>
-</p><pre>	          
+</p><pre>            
             &lt;FuzzyLikeThisQuery&gt;
                 &lt;Field fieldName="contents"&gt;
-		             Sumitimo bank
-	            &lt;/Field&gt;
+                 Sumitimo bank
+              &lt;/Field&gt;
             &lt;/FuzzyLikeThisQuery&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;FuzzyLikeThisQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;FuzzyLikeThisQuery&gt;'s children</th></tr>
@@ -965,8 +965,8 @@ appears commonly in the index.</em>
                 Iraq also reported a naval battle at the northern tip of the Gulf. Iraqi naval units and forces defending an 
                 offshore terminal sank six Iranian out of 28 Iranian boats attempting to attack an offshore terminal, 
                 the communique said.      Reuters 3;
-            &lt;/LikeThisQuery&gt;	         
-	        </pre><p></p><blockquote><table summary='element info'><tr>
+            &lt;/LikeThisQuery&gt;           
+          </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;LikeThisQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;LikeThisQuery&gt;'s attributes</th>
 </tr>
@@ -1015,7 +1015,7 @@ Child of <a href='#BoostQuery'>BoostQuer
 Unlike a regular BooleanQuery the boost can be less than 1 to produce a subtractive rather than additive result
 on the match score.</p><p><span class='inTextTitle'>Example:</span> <em>Find documents about banks, preferably related to mergers, and preferably not about "World bank"</em>
 </p><pre>
-	&lt;BoostingQuery&gt;
+  &lt;BoostingQuery&gt;
       &lt;Query&gt;
          &lt;BooleanQuery fieldName="contents"&gt;
            &lt;Clause occurs="should"&gt;
@@ -1024,13 +1024,13 @@ on the match score.</p><p><span class='i
            &lt;Clause occurs="must"&gt;
               &lt;TermQuery&gt;bank&lt;/TermQuery&gt;
            &lt;/Clause&gt;
-         &lt;/BooleanQuery&gt;	
+         &lt;/BooleanQuery&gt;  
       &lt;/Query&gt;
       &lt;BoostQuery boost="0.01"&gt;
          &lt;UserQuery&gt;"world bank"&lt;/UserQuery&gt;
       &lt;/BoostQuery&gt;
     &lt;/BoostingQuery&gt;
-	</pre><p></p><blockquote><table summary='element info'><tr>
+  </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;BoostingQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;BoostingQuery&gt;'s children</th></tr>
@@ -1109,11 +1109,11 @@ Child of <a href='#Clause'>Clause</a>, <
       &lt;Query&gt;
          &lt;TermQuery fieldName="text"&gt;lucene&lt;/TermQuery&gt;
       &lt;/Query&gt;
-	  &lt;Filter&gt;
-		&lt;DuplicateFilter fieldName="url" keepMode="last"/&gt;
-	  &lt;/Filter&gt;	
-    &lt;/FilteredQuery&gt;	
-	</pre><p></p><blockquote>
+    &lt;Filter&gt;
+    &lt;DuplicateFilter fieldName="url" keepMode="last"/&gt;
+    &lt;/Filter&gt;  
+    &lt;/FilteredQuery&gt;  
+  </pre><p></p><blockquote>
 <table  summary="&lt;DuplicateFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;DuplicateFilter&gt;'s attributes</th>
 </tr>
@@ -1151,11 +1151,11 @@ Child of <a href='#Clause'>Clause</a>, <
       &lt;Query&gt;
          &lt;TermQuery fieldName="text"&gt;lucene&lt;/TermQuery&gt;
       &lt;/Query&gt;
-	&lt;Filter&gt;
-		&lt;TermsFilter fieldName="dayOfWeek"&gt;monday friday&lt;/TermsFilter&gt; 
-	&lt;/Filter&gt;	
-    &lt;/FilteredQuery&gt;	
-	</pre><p></p><blockquote><table summary='element info'><tr>
+  &lt;Filter&gt;
+    &lt;TermsFilter fieldName="dayOfWeek"&gt;monday friday&lt;/TermsFilter&gt; 
+  &lt;/Filter&gt;  
+    &lt;/FilteredQuery&gt;  
+  </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;TermsFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;TermsFilter&gt;'s attributes</th>
 </tr>
@@ -1195,7 +1195,7 @@ Unlike BooleanQuery a BooleanFilter can
         &lt;/BooleanFilter&gt;
        &lt;/Filter&gt;
     &lt;/FilteredQuery&gt;
-	</pre><p></p><blockquote><table summary='element info'><tr>
+  </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;BooleanFilter&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;BooleanFilter&gt;'s children</th></tr>

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneCoreQuery.dtd.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneCoreQuery.dtd.html?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneCoreQuery.dtd.html (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/docs/xml/LuceneCoreQuery.dtd.html Wed Sep  2 13:06:13 2015
@@ -45,20 +45,20 @@ Child of <a href='#Clause'>Clause</a>, <
 </td></tr></table>
 <p>BooleanQuerys implement Boolean logic which controls how multiple Clauses should be interpreted.
 Some clauses may represent optional Query criteria while others represent mandatory criteria.</p><p><span class='inTextTitle'>Example:</span> <em>Find articles about banks, preferably talking about mergers but nothing to do with "sumitomo"</em>
-</p><pre>	          
+</p><pre>            
             &lt;BooleanQuery fieldName="contents"&gt;
-	             &lt;Clause occurs="should"&gt;
-		              &lt;TermQuery&gt;merger&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
-	             &lt;Clause occurs="mustnot"&gt;
-		              &lt;TermQuery&gt;sumitomo&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
-	             &lt;Clause occurs="must"&gt;
-		              &lt;TermQuery&gt;bank&lt;/TermQuery&gt;
-	             &lt;/Clause&gt;
+               &lt;Clause occurs="should"&gt;
+                  &lt;TermQuery&gt;merger&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
+               &lt;Clause occurs="mustnot"&gt;
+                  &lt;TermQuery&gt;sumitomo&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
+               &lt;Clause occurs="must"&gt;
+                  &lt;TermQuery&gt;bank&lt;/TermQuery&gt;
+               &lt;/Clause&gt;
             &lt;/BooleanQuery&gt;
 
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;BooleanQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;BooleanQuery&gt;'s children</th></tr>
@@ -150,18 +150,18 @@ Bitsets at a cost of 1 bit per document
 Queries that are cached as filters obviously retain none of the scoring information associated with results - they retain just
 a Boolean yes/no record of which documents matched.</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about banks from the last 10 years - caching the commonly-used "last 10 year" filter as a BitSet in
 RAM to eliminate the cost of building this filter from disk for every query</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;bank&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                   &lt;CachedFilter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
                   &lt;/CachedFilter&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;CachedFilter&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;CachedFilter&gt;'s children</th></tr>
@@ -194,9 +194,9 @@ RAM to eliminate the cost of building th
 Child of <a href='#Clause'>Clause</a>, <a href='#Query'>Query</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>Passes content directly through to the standard LuceneQuery parser see "Lucene Query Syntax"</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about John Smith or John Doe using standard LuceneQuerySyntax</em>
-</p><pre>	          
+</p><pre>            
                &lt;UserQuery&gt;"John Smith" OR "John Doe"&lt;/UserQuery&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;UserQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;UserQuery&gt;'s attributes</th>
 </tr>
@@ -227,24 +227,24 @@ is a "mustNot" match (Lucene requires at
 <li> in a FilteredQuery where a Filter tag is effectively being
 used to select content rather than its usual role of filtering the results of a query.</li>
 </ol></p><p><span class='inTextTitle'>Example:</span> <em>Effectively use a Filter as a query </em>
-</p><pre>	          
+</p><pre>            
                &lt;FilteredQuery&gt;
                  &lt;Query&gt;
                     &lt;MatchAllDocsQuery/&gt;
                  &lt;/Query&gt;
                  &lt;Filter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19870409" upperTerm="19870412"/&gt;
-                 &lt;/Filter&gt;	
-               &lt;/FilteredQuery&gt;	         
-	       </pre><p></p><p class='emptyTagNote'>This element is always empty.</p><a name='TermQuery'></a>
+                 &lt;/Filter&gt;  
+               &lt;/FilteredQuery&gt;           
+         </pre><p></p><p class='emptyTagNote'>This element is always empty.</p><a name='TermQuery'></a>
 <br /><table class='elementTitle' summary="TermQuery"><tr><td class='leftElementTitle'>
 &lt;TermQuery&gt;</td><td class='rightElementTitle'>
 Child of <a href='#Clause'>Clause</a>, <a href='#Query'>Query</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>a single term query - no analysis is done of the child text</p><p><span class='inTextTitle'>Example:</span> <em>Match on a primary key</em>
-</p><pre>	          
+</p><pre>            
                &lt;TermQuery fieldName="primaryKey"&gt;13424&lt;/TermQuery&gt;
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;TermQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;TermQuery&gt;'s attributes</th>
 </tr>
@@ -288,9 +288,9 @@ Child text is analyzed using a field-spe
 Unlike UserQuery element, this does not parse any special characters to control fuzzy/phrase/boolean logic and as such is incapable
 of producing a Query parse error given any user input</p><p><span class='inTextTitle'>Example:</span> <em>Match on text from a database description (which may contain characters that
 are illegal characters in the standard Lucene Query syntax used in the UserQuery tag</em>
-</p><pre>	          
+</p><pre>            
                &lt;TermsQuery fieldName="description"&gt;Smith & Sons (Ltd) : incorporated 1982&lt;/TermsQuery&gt;
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;TermsQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;TermsQuery&gt;'s attributes</th>
 </tr>
@@ -325,16 +325,16 @@ Attribute of <a href='#TermsQuery'>Terms
 Child of <a href='#Clause'>Clause</a>, <a href='#Query'>Query</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>Runs a Query and filters results to only those query matches that also match the Filter element.</p><p><span class='inTextTitle'>Example:</span> <em>Find all documents about Lucene that have a status of "published"</em>
-</p><pre>	          
+</p><pre>            
                &lt;FilteredQuery&gt;
                  &lt;Query&gt;
                     &lt;UserQuery&gt;Lucene&lt;/UserQuery&gt;
                  &lt;/Query&gt;
                  &lt;Filter&gt;
                      &lt;TermsFilter fieldName="status"&gt;published&lt;/TermsFilter&gt;
-                 &lt;/Filter&gt;	
-               &lt;/FilteredQuery&gt;	         
-	       </pre><p></p><blockquote><table summary='element info'><tr>
+                 &lt;/Filter&gt;  
+               &lt;/FilteredQuery&gt;           
+         </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;FilteredQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;FilteredQuery&gt;'s children</th></tr>
@@ -409,16 +409,16 @@ Child of <a href='#FilteredQuery'>Filter
 Child of <a href='#Clause'>Clause</a>, <a href='#ConstantScoreQuery'>ConstantScoreQuery</a>, <a href='#Filter'>Filter</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>Filter used to limit query results to documents matching a range of field values</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about banks from the last 10 years</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;bank&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                      &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;RangeFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;RangeFilter&gt;'s attributes</th>
 </tr>
@@ -458,9 +458,9 @@ Attribute of <a href='#RangeFilter'>Rang
 Child of <a href='#Clause'>Clause</a>, <a href='#Query'>Query</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>A Query that matches numeric values within a specified range.</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about people who are aged 20-25</em>
-</p><pre>	          
+</p><pre>            
             &lt;NumericRangeQuery fieldName="age" lowerTerm="20" upperTerm="25" /&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;NumericRangeQuery&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;NumericRangeQuery&gt;'s attributes</th>
 </tr>
@@ -510,16 +510,16 @@ Attribute of <a href='#NumericRangeQuery
 Child of <a href='#Clause'>Clause</a>, <a href='#ConstantScoreQuery'>ConstantScoreQuery</a>, <a href='#Filter'>Filter</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>A Filter that only accepts numeric values within a specified range</p><p><span class='inTextTitle'>Example:</span> <em>Search for documents about people who are aged 20-25</em>
-</p><pre>	          
+</p><pre>            
             &lt;FilteredQuery&gt;
                &lt;Query&gt;
                   &lt;UserQuery&gt;person&lt;/UserQuery&gt;
-               &lt;/Query&gt;	
+               &lt;/Query&gt;  
                &lt;Filter&gt;
                      &lt;NumericRangeFilter fieldName="age" lowerTerm="20" upperTerm="25"/&gt;
-               &lt;/Filter&gt;	
+               &lt;/Filter&gt;  
             &lt;/FilteredQuery&gt;
-	         </pre><p></p><blockquote>
+           </pre><p></p><blockquote>
 <table  summary="&lt;NumericRangeFilter&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;NumericRangeFilter&gt;'s attributes</th>
 </tr>
@@ -570,19 +570,19 @@ Child of <a href='#Include'>Include</a>,
 </td></tr></table>
 <p>A single term used in a SpanQuery. These clauses are the building blocks for more complex "span" queries which test word proximity</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms close to each other about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;SpanTerm&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;SpanTerm&gt;'s attributes</th>
 </tr>
@@ -604,11 +604,11 @@ Child of <a href='#Include'>Include</a>,
 <p>A field-specific analyzer is used here to parse the child text provided in this tag. The SpanTerms produced are ORed in terms of Boolean logic</p><p><span class='inTextTitle'>Example:</span> <em>Use SpanOrTerms as a more convenient/succinct way of expressing multiple choices of SpanTerms. This example looks for reports
 using words describing a fatality near to references to miners</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOrTerms&gt;killed died death dead deaths&lt;/SpanOrTerms&gt;
-			&lt;SpanOrTerms&gt;miner mining miners&lt;/SpanOrTerms&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOrTerms&gt;killed died death dead deaths&lt;/SpanOrTerms&gt;
+      &lt;SpanOrTerms&gt;miner mining miners&lt;/SpanOrTerms&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table  summary="&lt;SpanOrTerms&gt;'s attributes"><tr>
 <th class='title' colspan='3'>&lt;SpanOrTerms&gt;'s attributes</th>
 </tr>
@@ -629,19 +629,19 @@ Child of <a href='#Include'>Include</a>,
 </td></tr></table>
 <p>Takes any number of child queries from the Span family</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms close to each other about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanOr&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanOr&gt;'s children</th></tr>
@@ -692,19 +692,19 @@ Attribute of <a href='#SpanNear'>SpanNea
 </td></tr></table>
 <p>defines the maximum distance between Span elements where distance is expressed as word number, not byte offset</p><p><span class='inTextTitle'>Example:</span> <em>Find documents using terms within 8 words of each other talking about mining and accidents</em>
 </p><pre>
-	      &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;		
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-			&lt;SpanOr&gt;
-				&lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
-				&lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
-			&lt;/SpanOr&gt;
-	      &lt;/SpanNear&gt;
-	      </pre><p></p><p><span class='inTextTitle'>Required</span></p><a name='SpanNear_inOrder'></a>
+        &lt;SpanNear slop="8" inOrder="false" fieldName="text"&gt;    
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;killed&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;died&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;dead&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+      &lt;SpanOr&gt;
+        &lt;SpanTerm&gt;miner&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;mining&lt;/SpanTerm&gt;
+        &lt;SpanTerm&gt;miners&lt;/SpanTerm&gt;
+      &lt;/SpanOr&gt;
+        &lt;/SpanNear&gt;
+        </pre><p></p><p><span class='inTextTitle'>Required</span></p><a name='SpanNear_inOrder'></a>
 <br /><table class='attributeTitle' summary="inOrder"><tr><td class='leftAttributeTitle'>
 @inOrder</td><td class='rightAttributeTitle'>
 Attribute of <a href='#SpanNear'>SpanNear</a>
@@ -715,11 +715,11 @@ Attribute of <a href='#SpanNear'>SpanNea
 Child of <a href='#Include'>Include</a>, <a href='#Clause'>Clause</a>, <a href='#Query'>Query</a>, <a href='#SpanNear'>SpanNear</a>, <a href='#SpanOr'>SpanOr</a>, <a href='#Exclude'>Exclude</a>, <a href='#CachedFilter'>CachedFilter</a>
 </td></tr></table>
 <p>Looks for a SpanQuery match occuring near the beginning of a document</p><p><span class='inTextTitle'>Example:</span> <em>Find letters where the first 50 words talk about a resignation:</em>
-</p><pre>	          
-	         &lt;SpanFirst end="50"&gt;
-	               &lt;SpanOrTerms fieldName="text"&gt;resigning resign leave&lt;/SpanOrTerms&gt;
-	         &lt;/SpanFirst&gt;
-	         </pre><p></p><blockquote><table summary='element info'><tr>
+</p><pre>            
+           &lt;SpanFirst end="50"&gt;
+                 &lt;SpanOrTerms fieldName="text"&gt;resigning resign leave&lt;/SpanOrTerms&gt;
+           &lt;/SpanFirst&gt;
+           </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanFirst&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanFirst&gt;'s children</th></tr>
@@ -761,16 +761,16 @@ Child of <a href='#Include'>Include</a>,
 </p><pre>
           &lt;SpanNot fieldName="text"&gt;
              &lt;Include&gt;
-                &lt;SpanNear slop="2" inOrder="true"&gt;		
+                &lt;SpanNear slop="2" inOrder="true"&gt;    
                      &lt;SpanTerm&gt;social&lt;/SpanTerm&gt;
                      &lt;SpanTerm&gt;services&lt;/SpanTerm&gt;
-                &lt;/SpanNear&gt;				
+                &lt;/SpanNear&gt;        
              &lt;/Include&gt;
              &lt;Exclude&gt;
                 &lt;SpanTerm&gt;public&lt;/SpanTerm&gt;
              &lt;/Exclude&gt;
           &lt;/SpanNot&gt;
-	      </pre><p></p><blockquote><table summary='element info'><tr>
+        </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;SpanNot&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;SpanNot&gt;'s children</th></tr>
@@ -832,8 +832,8 @@ Child of <a href='#Clause'>Clause</a>, <
 </p><pre>
      &lt;ConstantScoreQuery&gt;
            &lt;RangeFilter fieldName="date" lowerTerm="19970101" upperTerm="20070101"/&gt;
-     &lt;/ConstantScoreQuery&gt;	
-	</pre><p></p><blockquote><table summary='element info'><tr>
+     &lt;/ConstantScoreQuery&gt;  
+  </pre><p></p><blockquote><table summary='element info'><tr>
 <td class='construct'><table summary="&lt;ConstantScoreQuery&gt;'s children">
 <thead>
 <tr><th class='title' colspan='2'>&lt;ConstantScoreQuery&gt;'s children</th></tr>

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParser.jj
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParser.jj?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParser.jj (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParser.jj Wed Sep  2 13:06:13 2015
@@ -1,4 +1,4 @@
-/**
+/*
  * 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.

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParserTokenManager.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParserTokenManager.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParserTokenManager.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/classic/QueryParserTokenManager.java Wed Sep  2 13:06:13 2015
@@ -12,6 +12,7 @@ import org.apache.lucene.search.TermRang
 import org.apache.lucene.search.TermQuery;
 
 /** Token Manager. */
+@SuppressWarnings("cast")
 public class QueryParserTokenManager implements QueryParserConstants
 {
 

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/config/NumericConfig.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/config/NumericConfig.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/config/NumericConfig.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/config/NumericConfig.java Wed Sep  2 13:06:13 2015
@@ -18,6 +18,7 @@ package org.apache.lucene.queryparser.fl
  */
 
 import java.text.NumberFormat;
+import java.util.Objects;
 
 import org.apache.lucene.document.FieldType.NumericType;
 import org.apache.lucene.search.NumericRangeQuery;
@@ -156,4 +157,9 @@ public class NumericConfig {
     
   }
   
+  @Override
+  public int hashCode() {
+    return Objects.hash(precisionStep, type, format);
+  }
+  
 }

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.java?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.java (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.java Wed Sep  2 13:06:13 2015
@@ -1,7 +1,7 @@
 /* Generated By:JavaCC: Do not edit this line. StandardSyntaxParser.java */
 package org.apache.lucene.queryparser.flexible.standard.parser;
 
-/**
+/*
  * 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.
@@ -708,6 +708,16 @@ public class StandardSyntaxParser implem
     finally { jj_save(1, xla); }
   }
 
+  private boolean jj_3R_12() {
+    if (jj_scan_token(RANGEIN_START)) return true;
+    return false;
+  }
+
+  private boolean jj_3R_11() {
+    if (jj_scan_token(REGEXPTERM)) return true;
+    return false;
+  }
+
   private boolean jj_3_1() {
     if (jj_scan_token(TERM)) return true;
     Token xsp;
@@ -811,16 +821,6 @@ public class StandardSyntaxParser implem
     return false;
   }
 
-  private boolean jj_3R_12() {
-    if (jj_scan_token(RANGEIN_START)) return true;
-    return false;
-  }
-
-  private boolean jj_3R_11() {
-    if (jj_scan_token(REGEXPTERM)) return true;
-    return false;
-  }
-
   /** Generated Token Manager. */
   public StandardSyntaxParserTokenManager token_source;
   /** Current token. */

Modified: lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.jj
URL: http://svn.apache.org/viewvc/lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.jj?rev=1700800&r1=1700799&r2=1700800&view=diff
==============================================================================
--- lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.jj (original)
+++ lucene/dev/branches/lucene6699/lucene/queryparser/src/java/org/apache/lucene/queryparser/flexible/standard/parser/StandardSyntaxParser.jj Wed Sep  2 13:06:13 2015
@@ -1,7 +1,3 @@
-/**
- * Standard file is based on the TextParser.jj from lucene 2.3
- */
-
 options {
   STATIC=false;
   JAVA_UNICODE_ESCAPE=true;
@@ -13,7 +9,7 @@ options {
 PARSER_BEGIN(StandardSyntaxParser)
 package org.apache.lucene.queryparser.flexible.standard.parser;
 
-/**
+/*
  * 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.