You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucene.apache.org by bu...@apache.org on 2011/02/22 02:01:11 UTC

svn commit: r1073192 [5/32] - in /lucene/dev/branches/realtime_search: ./ dev-tools/eclipse/ dev-tools/idea/.idea/ dev-tools/idea/lucene/contrib/ant/ dev-tools/idea/lucene/contrib/demo/ dev-tools/idea/lucene/contrib/highlighter/ dev-tools/idea/lucene/c...

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RangeQueryNode.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RangeQueryNode.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RangeQueryNode.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RangeQueryNode.java Tue Feb 22 01:00:39 2011
@@ -34,8 +34,6 @@ import org.apache.lucene.queryParser.sta
  */
 public class RangeQueryNode extends ParametricRangeQueryNode {
 
-  private static final long serialVersionUID = 7400866652044314657L;
-
   private Collator collator;
 
   /**

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RegexpQueryNode.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RegexpQueryNode.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RegexpQueryNode.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/RegexpQueryNode.java Tue Feb 22 01:00:39 2011
@@ -29,7 +29,6 @@ import org.apache.lucene.util.BytesRef;
  */
 public class RegexpQueryNode extends QueryNodeImpl  implements TextableQueryNode,
 FieldableNode {
-  private static final long serialVersionUID = 0L;
   private CharSequence text;
   private CharSequence field;
   /**

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/StandardBooleanQueryNode.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/StandardBooleanQueryNode.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/StandardBooleanQueryNode.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/StandardBooleanQueryNode.java Tue Feb 22 01:00:39 2011
@@ -34,8 +34,6 @@ import org.apache.lucene.search.Similari
  */
 public class StandardBooleanQueryNode extends BooleanQueryNode {
 
-  private static final long serialVersionUID = 1938287817191138787L;
-
   private boolean disableCoord;
 
   /**

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/WildcardQueryNode.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/WildcardQueryNode.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/WildcardQueryNode.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/nodes/WildcardQueryNode.java Tue Feb 22 01:00:39 2011
@@ -25,7 +25,6 @@ import org.apache.lucene.queryParser.cor
  * phrases. Examples: a*b*c Fl?w? m?ke*g
  */
 public class WildcardQueryNode extends FieldQueryNode {
-  private static final long serialVersionUID = 0L;
 
   /**
    * @param field

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/BoostQueryNodeProcessor.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/BoostQueryNodeProcessor.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/BoostQueryNodeProcessor.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/BoostQueryNodeProcessor.java Tue Feb 22 01:00:39 2011
@@ -26,6 +26,7 @@ import org.apache.lucene.queryParser.cor
 import org.apache.lucene.queryParser.core.nodes.FieldableNode;
 import org.apache.lucene.queryParser.core.nodes.QueryNode;
 import org.apache.lucene.queryParser.core.processors.QueryNodeProcessorImpl;
+import org.apache.lucene.queryParser.core.util.StringUtils;
 import org.apache.lucene.queryParser.standard.config.BoostAttribute;
 
 /**
@@ -49,7 +50,8 @@ public class BoostQueryNodeProcessor ext
       QueryConfigHandler config = getQueryConfigHandler();
 
       if (config != null) {
-        FieldConfig fieldConfig = config.getFieldConfig(fieldNode.getField());
+        CharSequence field = fieldNode.getField();
+        FieldConfig fieldConfig = config.getFieldConfig(StringUtils.toString(field));
 
         if (fieldConfig != null && fieldConfig.hasAttribute(BoostAttribute.class)) {
           BoostAttribute boostAttr = fieldConfig.getAttribute(BoostAttribute.class);

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/ParametricRangeQueryNodeProcessor.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/ParametricRangeQueryNodeProcessor.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/ParametricRangeQueryNodeProcessor.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/org/apache/lucene/queryParser/standard/processors/ParametricRangeQueryNodeProcessor.java Tue Feb 22 01:00:39 2011
@@ -97,8 +97,15 @@ public class ParametricRangeQueryNodePro
 
       }
 
-      FieldConfig fieldConfig = getQueryConfigHandler().getFieldConfig(
-          parametricRangeNode.getField());
+      CharSequence field = parametricRangeNode.getField();
+      String fieldStr = null;
+
+      if (field != null) {
+        fieldStr = field.toString();
+      }
+
+      FieldConfig fieldConfig = getQueryConfigHandler()
+          .getFieldConfig(fieldStr);
 
       if (fieldConfig != null) {
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/overview.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/overview.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/overview.html (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/java/overview.html Tue Feb 22 01:00:39 2011
@@ -138,11 +138,6 @@ you don't need to worry about dealing wi
       config.setAnalyzer(new WhitespaceAnalyzer());
       Query query = qpHelper.parse("apache AND lucene", "defaultField");
 </pre>
-<p>
-To make it easy for people who are using current Lucene's query parser to switch to
-the new one, there is a {@link org.apache.lucene.queryParser.standard.QueryParserWrapper} under org.apache.lucene.queryParser.standard
-that keeps the old query parser interface, but uses the new query parser infrastructure.
-</p>
 
 </body>
 </html>

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/core/builders/TestQueryTreeBuilder.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/core/builders/TestQueryTreeBuilder.java?rev=1073192&r1=1073113&r2=1073192&view=diff
==============================================================================
    (empty)

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/precedence/TestPrecedenceQueryParser.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/precedence/TestPrecedenceQueryParser.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/precedence/TestPrecedenceQueryParser.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/precedence/TestPrecedenceQueryParser.java Tue Feb 22 01:00:39 2011
@@ -84,6 +84,7 @@ public class TestPrecedenceQueryParser e
 
     OffsetAttribute offsetAtt = addAttribute(OffsetAttribute.class);
 
+    @Override
     public boolean incrementToken() throws IOException {
       if (inPhrase) {
         inPhrase = false;
@@ -108,6 +109,7 @@ public class TestPrecedenceQueryParser e
   public static final class QPTestAnalyzer extends Analyzer {
 
     /** Filters MockTokenizer with StopFilter. */
+    @Override
     public final TokenStream tokenStream(String fieldName, Reader reader) {
       return new QPTestFilter(new MockTokenizer(reader, MockTokenizer.SIMPLE, true));
     }
@@ -115,6 +117,7 @@ public class TestPrecedenceQueryParser e
 
   private int originalMaxClauses;
 
+  @Override
   public void setUp() throws Exception {
     super.setUp();
     originalMaxClauses = BooleanQuery.getMaxClauseCount();
@@ -567,6 +570,12 @@ public class TestPrecedenceQueryParser e
       // too many boolean clauses, so ParseException is expected
     }
   }
+  
+  // LUCENE-792
+  public void testNOT() throws Exception {
+    Analyzer a = new MockAnalyzer(MockTokenizer.WHITESPACE, false);
+    assertQueryEquals("NOT foo AND bar", a, "-foo +bar");
+  }
 
   /**
    * This test differs from the original QueryParser, showing how the precedence
@@ -621,6 +630,7 @@ public class TestPrecedenceQueryParser e
     
   }
 
+  @Override
   public void tearDown() {
     BooleanQuery.setMaxClauseCount(originalMaxClauses);
   }

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/SpansQueryConfigHandler.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/SpansQueryConfigHandler.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/SpansQueryConfigHandler.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/SpansQueryConfigHandler.java Tue Feb 22 01:00:39 2011
@@ -33,7 +33,7 @@ public class SpansQueryConfigHandler ext
   }
 
   @Override
-  public FieldConfig getFieldConfig(CharSequence fieldName) {
+  public FieldConfig getFieldConfig(String fieldName) {
 
     // there is no field configuration, always return null
     return null;

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/UniqueFieldAttributeImpl.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/UniqueFieldAttributeImpl.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/UniqueFieldAttributeImpl.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/spans/UniqueFieldAttributeImpl.java Tue Feb 22 01:00:39 2011
@@ -31,8 +31,6 @@ import org.apache.lucene.util.AttributeI
 public class UniqueFieldAttributeImpl extends AttributeImpl implements
     UniqueFieldAttribute {
 
-  private static final long serialVersionUID = 8553318595851064232L;
-
   private CharSequence uniqueField;
 
   public UniqueFieldAttributeImpl() {

Modified: lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/standard/TestQPHelper.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/standard/TestQPHelper.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/standard/TestQPHelper.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/queryparser/src/test/org/apache/lucene/queryParser/standard/TestQPHelper.java Tue Feb 22 01:00:39 2011
@@ -1277,12 +1277,13 @@ public class TestQPHelper extends Lucene
     Document doc = new Document();
     doc.add(newField("field", "", Field.Store.NO, Field.Index.ANALYZED));
     w.addDocument(doc);
-    IndexReader r = IndexReader.open(w);
-    IndexSearcher s = new IndexSearcher(r);
+    IndexReader r = IndexReader.open(w, true);
+    IndexSearcher s = newSearcher(r);
     
     Query q = new StandardQueryParser(new CannedAnalyzer()).parse("\"a\"", "field");
     assertTrue(q instanceof MultiPhraseQuery);
     assertEquals(1, s.search(q, 10).totalHits);
+    s.close();
     r.close();
     w.close();
     dir.close();

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashDistanceFilter.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashDistanceFilter.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashDistanceFilter.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashDistanceFilter.java Tue Feb 22 01:00:39 2011
@@ -36,11 +36,6 @@ import org.apache.lucene.spatial.tier.Di
  */
 
 public class GeoHashDistanceFilter extends DistanceFilter {
-
-  /**
-   * 
-   */
-  private static final long serialVersionUID = 1L;
   
   private double lat;
   private double lng;

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashUtils.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashUtils.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashUtils.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/geohash/GeoHashUtils.java Tue Feb 22 01:00:39 2011
@@ -22,7 +22,7 @@ import java.util.Map;
 
 /**
  * Utilities for encoding and decoding geohashes. Based on
- * http://en.wikipedia.org/wiki/Geohash.
+ * <a href="http://en.wikipedia.org/wiki/Geohash">http://en.wikipedia.org/wiki/Geohash</a>.
  */
 public class GeoHashUtils {
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFieldComparatorSource.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFieldComparatorSource.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFieldComparatorSource.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFieldComparatorSource.java Tue Feb 22 01:00:39 2011
@@ -31,8 +31,6 @@ import org.apache.lucene.search.FieldCom
  */
 public class DistanceFieldComparatorSource extends FieldComparatorSource {
 
-	private static final long serialVersionUID = 1L;
-
 	private DistanceFilter distanceFilter;
 	private DistanceScoreDocLookupComparator dsdlc;
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFilter.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFilter.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFilter.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceFilter.java Tue Feb 22 01:00:39 2011
@@ -19,8 +19,6 @@ package org.apache.lucene.spatial.tier;
 import java.util.Map;
 import java.util.WeakHashMap;
 import java.util.HashMap;
-import java.io.IOException;
-import java.io.ObjectInputStream;
 
 import org.apache.lucene.search.Filter;
 import org.apache.lucene.spatial.tier.DistanceHandler.Precision;
@@ -63,12 +61,6 @@ public abstract class DistanceFilter ext
     distanceLookupCache = new WeakHashMap<String,Double>();
   }
 
-  /** needed for deserialization, because the cache is transient */
-  private void readObject(ObjectInputStream stream) throws IOException, ClassNotFoundException {
-    stream.defaultReadObject();
-    distanceLookupCache = new WeakHashMap<String,Double>();
-  }
-
   public Map<Integer,Double> getDistances(){
     return distances;
   }

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceQueryBuilder.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceQueryBuilder.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceQueryBuilder.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/DistanceQueryBuilder.java Tue Feb 22 01:00:39 2011
@@ -30,8 +30,6 @@ import org.apache.lucene.spatial.geohash
  * release.</font>
  */
 public class DistanceQueryBuilder {
-
-  private static final long serialVersionUID = 1L;
   
   private final double lat;
   private final double lng;

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/InvalidGeoException.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/InvalidGeoException.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/InvalidGeoException.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/InvalidGeoException.java Tue Feb 22 01:00:39 2011
@@ -24,11 +24,6 @@ package org.apache.lucene.spatial.tier;
  */
 public class InvalidGeoException extends Exception {
 
-  /**
-   * 
-   */
-  private static final long serialVersionUID = 1L;
-
   public InvalidGeoException(String message){
     super(message);
   }

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/LatLongDistanceFilter.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/LatLongDistanceFilter.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/LatLongDistanceFilter.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/LatLongDistanceFilter.java Tue Feb 22 01:00:39 2011
@@ -33,11 +33,6 @@ import org.apache.lucene.spatial.Distanc
  * release.</font>
  */
 public class LatLongDistanceFilter extends DistanceFilter {
-
-  /**
-   * 
-   */
-  private static final long serialVersionUID = 1L;
   
   double lat;
   double lng;

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/Shape.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/Shape.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/Shape.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/java/org/apache/lucene/spatial/tier/Shape.java Tue Feb 22 01:00:39 2011
@@ -17,7 +17,6 @@
 
 package org.apache.lucene.spatial.tier;
 
-import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.List;
 
@@ -26,7 +25,7 @@ import java.util.List;
  * flux and might change in incompatible ways in the next
  * release.</font>
  */
-public class Shape implements Serializable{
+public class Shape {
 
   private List<Double> area = new ArrayList<Double>();
   private String tierId;

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/geometry/TestDistanceUnits.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/geometry/TestDistanceUnits.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/geometry/TestDistanceUnits.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/geometry/TestDistanceUnits.java Tue Feb 22 01:00:39 2011
@@ -1,5 +1,22 @@
 package org.apache.lucene.spatial.geometry;
 
+/**
+ * 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.
+ */
+
 import org.apache.lucene.util.LuceneTestCase;
 import org.junit.Test;
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/TestDistance.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/TestDistance.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/TestDistance.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/TestDistance.java Tue Feb 22 01:00:39 2011
@@ -99,7 +99,7 @@ public class TestDistance extends Lucene
 
   public void testLatLongFilterOnDeletedDocs() throws Exception {
     writer.deleteDocuments(new Term("name", "Potomac"));
-    IndexReader r = IndexReader.open(writer);
+    IndexReader r = IndexReader.open(writer, true);
     LatLongDistanceFilter f = new LatLongDistanceFilter(new QueryWrapperFilter(new MatchAllDocsQuery()),
                                                         lat, lng, 1.0, latField, lngField);
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/projections/SinusoidalProjectorTest.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/projections/SinusoidalProjectorTest.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/projections/SinusoidalProjectorTest.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/spatial/src/test/org/apache/lucene/spatial/tier/projections/SinusoidalProjectorTest.java Tue Feb 22 01:00:39 2011
@@ -1,5 +1,22 @@
 package org.apache.lucene.spatial.tier.projections;
 
+/**
+ * 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.
+ */
+
 import org.apache.lucene.util.LuceneTestCase;
 import org.junit.Test;
 

Modified: lucene/dev/branches/realtime_search/lucene/contrib/wordnet/src/java/org/apache/lucene/wordnet/SynonymMap.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/wordnet/src/java/org/apache/lucene/wordnet/SynonymMap.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/wordnet/src/java/org/apache/lucene/wordnet/SynonymMap.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/wordnet/src/java/org/apache/lucene/wordnet/SynonymMap.java Tue Feb 22 01:00:39 2011
@@ -52,15 +52,17 @@ import java.util.TreeSet;
  * high-frequency lookups of medium size synonym tables.
  * <p>
  * Example Usage:
- * <pre>
+ * <pre class="prettyprint">
  * String[] words = new String[] { "hard", "woods", "forest", "wolfish", "xxxx"};
  * SynonymMap map = new SynonymMap(new FileInputStream("samples/fulltext/wn_s.pl"));
  * for (int i = 0; i &lt; words.length; i++) {
  *     String[] synonyms = map.getSynonyms(words[i]);
  *     System.out.println(words[i] + ":" + java.util.Arrays.asList(synonyms).toString());
  * }
- * 
+ * </pre>
+ * <b/>
  * Example output:
+ * <pre class="prettyprint">
  * hard:[arduous, backbreaking, difficult, fermented, firmly, grueling, gruelling, heavily, heavy, intemperately, knockout, laborious, punishing, severe, severely, strong, toilsome, tough]
  * woods:[forest, wood]
  * forest:[afforest, timber, timberland, wood, woodland, woods]
@@ -161,7 +163,7 @@ public class SynonymMap {
     return word.toLowerCase();
   }
 
-  private static boolean isValid(String str) {
+  protected boolean isValid(String str) {
     for (int i=str.length(); --i >= 0; ) {
       if (!Character.isLetter(str.charAt(i))) return false;
     }
@@ -395,4 +397,4 @@ public class SynonymMap {
     }
   }
   
-}
\ No newline at end of file
+}

Modified: lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/java/org/apache/lucene/xmlparser/builders/NumericRangeFilterBuilder.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/java/org/apache/lucene/xmlparser/builders/NumericRangeFilterBuilder.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/java/org/apache/lucene/xmlparser/builders/NumericRangeFilterBuilder.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/java/org/apache/lucene/xmlparser/builders/NumericRangeFilterBuilder.java Tue Feb 22 01:00:39 2011
@@ -154,7 +154,6 @@ public class NumericRangeFilterBuilder i
 	}
 
 	static class NoMatchFilter extends Filter {
-		private static final long serialVersionUID = 1L;
 
 		@Override
 		public DocIdSet getDocIdSet(AtomicReaderContext context) throws IOException {

Modified: lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/test/org/apache/lucene/xmlparser/TestParser.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/test/org/apache/lucene/xmlparser/TestParser.java?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/test/org/apache/lucene/xmlparser/TestParser.java (original)
+++ lucene/dev/branches/realtime_search/lucene/contrib/xml-query-parser/src/test/org/apache/lucene/xmlparser/TestParser.java Tue Feb 22 01:00:39 2011
@@ -21,6 +21,7 @@ import org.apache.lucene.store.Directory
 import org.apache.lucene.util.Version;
 import org.apache.lucene.util.LuceneTestCase;
 import org.junit.AfterClass;
+import org.junit.Assume;
 import org.junit.BeforeClass;
 /**
  * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -73,7 +74,7 @@ public class TestParser extends LuceneTe
 			d.close();
       writer.close();
 		reader=IndexReader.open(dir, true);
-		searcher=new IndexSearcher(reader);
+		searcher=newSearcher(reader);
 		
 	}
 	
@@ -186,6 +187,7 @@ public class TestParser extends LuceneTe
 	}
 	public void testDuplicateFilterQueryXML() throws ParserException, IOException
 	{
+                        Assume.assumeTrue(searcher.getIndexReader().getSequentialSubReaders().length == 1);
 			Query q=parse("DuplicateFilterQuery.xml");
 			int h = searcher.search(q, null, 1000).totalHits;
 			assertEquals("DuplicateFilterQuery should produce 1 result ", 1,h);

Modified: lucene/dev/branches/realtime_search/lucene/docs/contributions.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/contributions.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/contributions.html (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/contributions.html Tue Feb 22 01:00:39 2011
@@ -129,11 +129,8 @@ document.write("Last Published: " + docu
 <div class="menuitem">
 <a href="api/core/index.html">Core</a>
 </div>
-<div class="menuitem">
-<a href="api/demo/index.html">Demo</a>
-</div>
-<div onclick="SwitchMenu('menu_1.1.3.4', 'skin/')" id="menu_1.1.3.4Title" class="menutitle">Contrib</div>
-<div id="menu_1.1.3.4" class="menuitemgroup">
+<div onclick="SwitchMenu('menu_1.1.3.3', 'skin/')" id="menu_1.1.3.3Title" class="menutitle">Contrib</div>
+<div id="menu_1.1.3.3" class="menuitemgroup">
 <div class="menuitem">
 <a href="api/contrib-ant/index.html">Ant</a>
 </div>
@@ -147,6 +144,9 @@ document.write("Last Published: " + docu
 <a href="api/contrib-benchmark/index.html">Benchmark</a>
 </div>
 <div class="menuitem">
+<a href="api/contrib-demo/index.html">Demo</a>
+</div>
+<div class="menuitem">
 <a href="api/contrib-highlighter/index.html">Highlighter</a>
 </div>
 <div class="menuitem">

Modified: lucene/dev/branches/realtime_search/lucene/docs/demo.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/demo.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/demo.html (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/demo.html Tue Feb 22 01:00:39 2011
@@ -129,11 +129,8 @@ document.write("Last Published: " + docu
 <div class="menuitem">
 <a href="api/core/index.html">Core</a>
 </div>
-<div class="menuitem">
-<a href="api/demo/index.html">Demo</a>
-</div>
-<div onclick="SwitchMenu('menu_1.1.3.4', 'skin/')" id="menu_1.1.3.4Title" class="menutitle">Contrib</div>
-<div id="menu_1.1.3.4" class="menuitemgroup">
+<div onclick="SwitchMenu('menu_1.1.3.3', 'skin/')" id="menu_1.1.3.3Title" class="menutitle">Contrib</div>
+<div id="menu_1.1.3.3" class="menuitemgroup">
 <div class="menuitem">
 <a href="api/contrib-ant/index.html">Ant</a>
 </div>
@@ -147,6 +144,9 @@ document.write("Last Published: " + docu
 <a href="api/contrib-benchmark/index.html">Benchmark</a>
 </div>
 <div class="menuitem">
+<a href="api/contrib-demo/index.html">Demo</a>
+</div>
+<div class="menuitem">
 <a href="api/contrib-highlighter/index.html">Highlighter</a>
 </div>
 <div class="menuitem">
@@ -243,7 +243,7 @@ document.write("Last Published: " + docu
 <a href="#About this Document">About this Document</a>
 </li>
 <li>
-<a href="#About the Demos">About the Demos</a>
+<a href="#About the Demo">About the Demo</a>
 </li>
 <li>
 <a href="#Setting your CLASSPATH">Setting your CLASSPATH</a>
@@ -269,12 +269,12 @@ It walks you through some basic installa
 
 
 
-<a name="N1001C"></a><a name="About the Demos"></a>
-<h2 class="boxed">About the Demos</h2>
+<a name="N1001C"></a><a name="About the Demo"></a>
+<h2 class="boxed">About the Demo</h2>
 <div class="section">
 <p>
-The Lucene command-line demo code consists of two applications that demonstrate various
-functionalities of Lucene and how one should go about adding Lucene to their applications.
+The Lucene command-line demo code consists of an application that demonstrates various
+functionalities of Lucene and how you can add Lucene to your applications.
 </p>
 </div>
 
@@ -285,19 +285,38 @@ functionalities of Lucene and how one sh
 <p>
 First, you should <a href="http://www.apache.org/dyn/closer.cgi/lucene/java/">download</a> the
 latest Lucene distribution and then extract it to a working directory.  Alternatively, you can <a href="http://wiki.apache.org/lucene-java/SourceRepository">check out the sources from
-Subversion</a>, and then run <span class="codefrag">ant war-demo</span> to generate the JARs and WARs.
+Subversion</a>, and then run <span class="codefrag">ant</span> in the <span class="codefrag">lucene/contrib/demo/</span>
+directory to generate the JARs.
 </p>
 <p>
-You should see the Lucene JAR file in the directory you created when you extracted the archive.  It
-should be named something like <span class="codefrag">lucene-core-{version}.jar</span>.  You should also see a file
-called <span class="codefrag">lucene-demos-{version}.jar</span>.  If you checked out the sources from Subversion then
-the JARs are located under the <span class="codefrag">build</span> subdirectory (after running <span class="codefrag">ant</span>
-successfully).  Put both of these files in your Java CLASSPATH.
+You need three JARs: the Lucene JAR, the common analysis JAR, and the Lucene demo JAR.  You should
+see the Lucene JAR file in the directory you created when you extracted the archive -- it
+should be named something like <span class="codefrag">lucene-core-{version}.jar</span>.  You should also see files
+called <span class="codefrag">lucene-analysis-common-{version}.jar</span> and <span class="codefrag">lucene-demos-{version}.jar</span>.
+If you checked out the sources from Subversion then the JARs are located at:
+</p>
+<ul>
+  
+<li>
+<span class="codefrag">lucene/build/lucene-core-4.0-SNAPSHOT.jar</span>
+</li>
+  
+<li>
+<span class="codefrag">modules/analysis/build/common/lucene-analyzers-common-4.0-SNAPSHOT.jar</span>
+</li>
+  
+<li>
+<span class="codefrag">lucene/build/contrib/demo/lucene-demo-4.0-SNAPSHOT.jar</span>
+</li>
+
+</ul>
+<p>
+Put all three of these files in your Java CLASSPATH.
 </p>
 </div>
 
 
-<a name="N10048"></a><a name="Indexing Files"></a>
+<a name="N1005A"></a><a name="Indexing Files"></a>
 <h2 class="boxed">Indexing Files</h2>
 <div class="section">
 <p>
@@ -305,7 +324,7 @@ Once you've gotten this far you're proba
 you've set your CLASSPATH correctly, just type:
 
 <pre>
-    java org.apache.lucene.demo.IndexFiles {full-path-to-lucene}/src
+    java org.apache.lucene.demo.IndexFiles -docs {path-to-lucene}/src
 </pre>
 
 This will produce a subdirectory called <span class="codefrag">index</span> which will contain an index of all of the
@@ -326,7 +345,7 @@ you whether you want more results.
 </div>
 
 
-<a name="N10063"></a><a name="About the code..."></a>
+<a name="N10075"></a><a name="About the code..."></a>
 <h2 class="boxed">About the code...</h2>
 <div class="section">
 <p>

Modified: lucene/dev/branches/realtime_search/lucene/docs/demo.pdf
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/demo.pdf?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/demo.pdf (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/demo.pdf Tue Feb 22 01:00:39 2011
@@ -5,10 +5,10 @@
 /Producer (FOP 0.20.5) >>
 endobj
 5 0 obj
-<< /Length 615 /Filter [ /ASCII85Decode /FlateDecode ]
+<< /Length 620 /Filter [ /ASCII85Decode /FlateDecode ]
  >>
 stream
-Gaua<9lHd\&;KZO$6PI!?%6<CP-iV[<N3S;[rr8rS-4]$>qk[>h\QrZS[;SS9*tq%RUKg"Z-=iJi,V6e@1\!3'-R1n!sH%5#,o-gM!\Hg&>W_;dQP+4,u7[XPB1\/7+Ao>h6sjnT"]0]79`e]WO?[k;oKaS!U7po!1:=t2l\T8<?6L#r.p94.<?l?jB`?l038uuEe$.W^c@$,@KV02CAHj//>4$?<TUQg7s>#Bp5qGZ?qA1f]/4l9qWt_?2:EL'cF#E*R:c*3!Ck-/0XCNFDE8O<J(V4oJ\h<J^30"F>N6or?.h2[V=Slf,qoS;K]fqX$ud%MC+h7cPP?[U:^fU"'&U0IL[V?uh&+DIdDl;"6G?7r_&sh]k]?hfla8Q]3%>0u=5DG&/T6jGqH&jZ3)^jab#@g6E8GGq!JO7#He(-UOT1?^=(N\mBt[#]19e)\_:&\L!JaIgHe/5Op:2edT?ObYU-JMC2SaGRr9aARs80`*5f((_ZiWP15qTo"p`1o%59aUF&<)EQghTEIEu9ZP`,n*A9E"KdQeS'N5OeuqYu:e!d&GO`,cA=lXZ,AgX1apdDH2ge;CeqB,ZWqo+1q'MCh3Jq$g>sp!2=LlrV~>
+Gaua<9l...@r9cX>rr^526HS!<li_onK1^]#n3'lr*JmJC680[JEN^Noc=%tXM!/p\f&kr%.eX,5IcEX!a%d5"KN!`b9?t0&f'Ma%>'VnCe*&p%L!a4rLs+5'5'H=-<NGC^jj9_$"^lY8)Z~>
 endstream
 endobj
 6 0 obj
@@ -42,7 +42,7 @@ endobj
 10 0 obj
 << /Type /Annot
 /Subtype /Link
-/Rect [ 102.0 500.966 194.66 488.966 ]
+/Rect [ 102.0 500.966 189.992 488.966 ]
 /C [ 0 0 0 ]
 /Border [ 0 0 0 ]
 /A 11 0 R
@@ -80,10 +80,10 @@ endobj
 >>
 endobj
 18 0 obj
-<< /Length 2210 /Filter [ /ASCII85Decode /FlateDecode ]
+<< /Length 2293 /Filter [ /ASCII85Decode /FlateDecode ]
  >>
 stream
-Gatm=gQ(#H&:O:SW;D_\L`''6pE@=idS1AXBppnU'MTZ_M7/\77>IVg0nT=M8,&].\o&DhfNh)n3HO?,n-jBESGfa`I@f+;>"#f7<PL[hX5CY)Lb)2:/G%$qYH6Eo-FOZa*rP[.lL-b+$$AC(EbdQ0I<Mre4hD.T>(*V[cYRAQK,*;d[@4(d$_I[TEbG@DR$&iJgo6WcI(^/h)MW!r(;o@4Ls$gbiVhZbnkJ-HXd=Le>3'uT$A-PM)!Mh3(3LORFDDjg]Wa,&WU6)F4*FEhgGDto:O"WW@H]9^rk-s(V:'`I4=Lu.MC2KCP>.Gl*-j/k^WSs5bAstb/G!+nX0u],[q3d)hVtC/Ce)EXI89Q4'IX6jOhV-eh'8hXU;U8-;/Wh`/$VI2Y?6q,(bK\fbEtmjDK$p<q)[>rZMoU:0`OqKqGBYnJJ`%AWkmbO+UMt__9"]-<93ht$;Vm<rEqorfD2TqomNG`\s->m"aN@Q[f]aq=c/hP6,qe-g5N[8$\dRkf#Y<&R`P4"/</rq("dr3oW97g&4X%I"-]]4M^^:TSjUB?[<7nXe`n\Y<QYatNEt+;ZkWg&$\)2n7@Bi&2qTiJTI`[AZl8Cho+Q_Jb%ZZ\.#ArL(uTcHM(:mr;1l'18:3?K99A#OOV_r>n*]%>07Pj#flfpm7Wp+E+Up%IZNi_.0!0"i=fA6Q)D_k++qAlF=COfa-ni50k---sF.'2R1IVT#6a-8$i,O\d!&[IP<:18`hUf!';VctOicL2.WT:;snqcU(VRXj$4:aP9RQu]IZ7t/+p`:%(=I':"DN$Ad/]A3^Tj0a"=TC-O01#k<T%:el[u6G(qmK"flKSkcrp83%$%TG>2[:\m9s&0^5,Aeo!s3ldNl2,GY1F^(L,[^+$A3t\^ah0S+]PD=g[!1,r%,?lh_>k^%MXdW6a+qnYXZqU'/:a;a,r@e/S*SE/[P74PpX.f(;h<:A@r(d)W\aPNYO<5B03b/,o/c
 'iUW2/p\YGtSAg(2_EbRXX'qR>6Lss(QGDD!-RR.Na9s@266=YhT"om]6e**%b-F>NBY[;]N^41UOI/1S4;)o8`i[.dBY3&08kCjC#`!A9,#hQIE7@Y+b61RZ.eG`NERceoR<-J#ETn:EcM\B_\XYEu$>DF#H0'=_mAi"eP&mQgGYTS#j_>u65<`[p`T7e=DY:?*h<T?]V:;ngrMWF0.dM2moP3K\9e"4%i_ll$/3A<.K#mF&LNk*Z')7nHh"$'_bgq(bPH&lF*`,2q)WO=;,r`1;7C(u`V<%K<2YS,?4IdP0V(Z#S\o%@&#U@s!+M#/AJuUQ=6l<HeoGa?#q^ml>L>ns51u8M7oK9t'l'b1l.Sc8B'J$W7&3Wr,l_R]F:^'2F/Q\"[5&H/ca!mkc@.k7s2FUL2%(aN69_(6Za.=&ORE1%,lHmbr.f2'qoVod':`]<.BCo(HUlZP4p'_9MBdt^6.P7V+J7GaO&*;@+bl:kCe9oTlG-8cr=le>D6D@dg^L]C#=f)?M.HB[QA%K,HlS/GeT6PgXRotO0>]KB!l(l3TNOL7XToE#&c)1P^(=CK\S<.9m^bEFpW:H<e<HI#)UCobil'sFM;.n<T41d#&A(Y[0n+TZCY$V-/YEp@l*asP"HFiP<g<m>E;WGfNGC_giP0YH+RZ&Op4^G'Bf+&eP&85gc4AW20E/ke)ijlp]n3&uKZdU/hbY4SO8QWs+>7u;0&X-&,7t#7%,QfG*PXYn<D:u06g'DTeH%Tm1Nn=G9PaTD?C%(P>KYfh%i0\HOFNCYcc8FKaiAbQ`Fc(8B!B=*U'UE!hE]W9:XhaLL<T^RFnF%u!$dBT=!e[c!YmmjTa:#-U"cbPn5al6n0jt7NK9+J"^/EJS:sGX8iGpcS\!Z-4hjok,meo](i]tQN+N\T-BV>g#[$&DCn:n5$MM)i.$]V1B4&[+Y!%nj:1o)D`e.Zqu\8B<Z5C_N32NAMP(*iM>7)Z!c'iL
 ApB@3f"?'iiONA.Hf2$YLXs(JQpDCRZpAlSf7,tU=Mh:tDZ5?"?%DS#`2rlN@B?D<99@+KR?LEuLr]PQU&'jU&7/in1-#<1J[[2,DB_q*T:D+=/e3=%6P2fJk7SC$lTJ#CZY=uc#Ra91@6Zd]Af5K\)SXeQt-(&f9qT+3*d[Y&#<k%un>T\&3cYuZXgBJrY("Z099%=LIC8a^1emp2S@1^`f)-\u^@!6c9H('~>
+Gatm=99Yi)&AJ$CY]ECE.[EAN_7@f94*adTREbMig>)i8fd;?6,K)Ru<;ud'Gd];HB!SD8nfU1q5JI-.>?ia-Ik2sS-8l/HU$Z%K^ZRTA^Mbblb7Yc;r:&_sCU11$D9[J>IQ_%D:E?&eY%J&QXX8NmY*P:)F^R5pL#mVi>FPr#!.U#/:\@t;I;UW\emD2no"-cUeM9oR=1jdr:i=aV+2-`T\RRW^s2S<WX`\T_V-c(m\K2(?o2[1Tkn<fX6YhO#BrFD3TGD.=m?huW[Wh5i1m]ah=OQ)`d*nr.]\"nedsTX%.:a\L9.p'&Rkd\Td[^'`AYIA.EjVSio3?Vl[qM%NA^#2GfLsiL%LHuo:=tRCa9cdH^5",K6V8AEM74,1gh`*RI"sUe77A,)COso:(<Mg(#%_88YL?2pWcn_loDaKD+,7`"JT2I,R[O'r+EO%'G,"/MMA1OHp,$7.T.c#dd`5hHpO0>\,A&suj5,U(*E[HQV>+q+aje(hBJ]3'/L5?m?XjV?lhs"?j+.U"2Nmo+i+_[(6OVa@,3<AjL.'po,\T&>Q[,Z5O0V`^bTP;0@gte0IPAPpehfr2o7Ass?jSQ&JDumsPYuHRr<\!([*6GAH7f9_m>u@17:*X=]Y2"h>eW)ueTOLa68g#bgEH0D+Ou*OY76oc<#"nk_'-d`QPjg2_@Lq3UVm^ER=^Y[HS#7,Mf_sj+W+;l4^qb!VD0EA3K=,.jTdF+.^P]Jf`SCMXl;o%==h!B@a<%?'01U+Sn1EU;)FNW>8H+i+>?\g!R?[E]W;:o+Y].]HR9(Rbd.OW#-pjriTtl1ib%*A#V`9]E7F"20kC'$6(Hnu1`nU8*,scK;CQ;o`3FlakFOj`X'dXa;H%7r.6a2kOc2UAF0\9u]l?/N?iri:#%tT^r7I-aXr:,Bf^A89HTc"8F,"(Toq)1+_kVFJ).$="6'$sQ3u5?!d3fIpE@18QKW",D?LP0I/<42udlAU#R)u]
 [l6=HM)1%P0L,DGjX%/gji*.JP6&Q3>h1e8GgEYuFo:?7G&L%g*JHblhe*/h"%5"nQF7O""V,YDMeB=6MZh3ZjppefuMh()5f&8EE\R<m)%;C2;T-J>.]'YW6L<^jF%qM&f%#13?=htQ':jtm4NM3B=*&+6;V)D2-$uaarfuCh7%ZUd0m"Ng%%$n!S`@+-NZ)`<Y,#m+eK/]Zb5kT8=jh<W]=sXf?Q=#_GL<8K*_/:sqq<in[EB)l5cXT-9,5Jl-Lh!ZiYL6(MdGL2bB9Pg;ba8o=`i;_=A;10d;Sr)"rT2;klOQY50d\nCW6ub8LPJ3.a-../4_mpJ85s)?L*?FI\=gh-UP3f`i-q2XmRcJ]U7j,r!,WLo:c5fo6M(]k-UbEu1ZGP;n5YiI,1RPN<Pi[LHW8mFFn)Z:mOA&pI4>-alCJ3[=nHI0GW=(AKRMC\rjp\4:s@D(JMt@1,Z"^l%k6Y?Y:?WN^%d]09XE^lSAI0h8u@^P/hPY:d&5lbh[@/U<Z+NNWJpLLVNkL.=lLHc:XD9?/B=73<8$Us</qb`\MMb+e:YKJeU+6/_5%B2W3,@./tqP>XlB@ci^QBYpC,SrT/AlSYp%LY!Wj`lHk@*#U]LPi\LtV^&DE"+9mDUJoPG\lm8WXj^"i?b+j_ZtIf=I\EU\OKOqL+^M-6(DOh0h5WS)p.%mj&.\8p*0jQeBm-QTX0]JW9`BIXp=2lID`%J0s3`i2G&U]C^gCXkJN@\FDmg*Sce8=Q_P9<AP!Kqi(gJ\42LWnV:eCRmJZG^G&8?0QpPgM=oWc%Un5&ac65l6taeag;h/#uZhJ2TFI%@5`\&>`8@[bK#LW?n[g52r5)6fTDPd*crZiWH^JkN1eecHcXd5V?lO[A[EWe8h:ZG#DQgC76.`IbbXh7ZVun2"1BU6M%=pij0LLtGH?a55$-<0I\G%mo$%@3ULp7/[NDaSjHhKP"d>c"GPP[jEGr<9EuYEE"PY0u6Bd
 .pR))=6d0;BHdXp^YJRg.;_ds9@M$e?^EuaY'*(W)5cXtPI0eo'F8K?\b&j%^@eKZ)a;Ca#ahY)ZALZTn%TSK5!HGdp`%Fd/[?n?mi`E;PG9srB6b-_[L\sn]9h=s]mlp#kl%Q:q658J?bL8X8#,>rA,4!9+3PVP.j^+*[ED'@pJeb)4&2fu/*PWV7,m7lX%DDR0oV(0mXWtbqTi;)TkQ(niJkIq[W?oY&jl36&e7Cq/Q%LH+B$oPH]oHS,*o7#1SYoY$_=6!N!QA:2"l9!V1b`haA82mZjCH\Wi0$kH8?uaL*<58D;54,?=~>
 endstream
 endobj
 19 0 obj
@@ -94,80 +94,95 @@ endobj
 /Contents 18 0 R
 >>
 endobj
+20 0 obj
+<< /Length 471 /Filter [ /ASCII85Decode /FlateDecode ]
+ >>
+stream
+GarnSbAMqd&A7ljp6Zo\fZ(pMM%nYjC=PZngtEehE!R)m.?IU/qjL$.8R!?HAsqJGSTPXAgDG>]JqGa"*jd;mZonR!"+VkRs*m4N!/1Ohn--:>0&#bS'ps:e.LfVSKVB;8ee2XhLj+Y?L27%j;!:igBB_Uu#C)dGHj+TBQ'nb_k1#?og$94q-Iir;niOear<0JX]G^?d*!a3-<l?Cu'0QCFlh*rZ=<a*FPY.uuChUuQE]LL2X;M/.s2pYW:;Xk3I<AL\Y?4C:8tWrdiKWPH)OaGuFNTLu0=+5HQ0AG/Q$&jZif_kt1lG>(-^2W24rDnUFq^Ea8gK^3n;:U#>,ugZX6?1^L=T]lN;BKYBlD<PMNVE:3+.mWBDYX6*;T^<DI'#cWG?SQY4?Ddm9Kpuo5@=L&MZWM&]MZ7*H3"en;GsW?`J,jCNCt(e`<UG:0LMRT^,lF=P(.\e>[N<IK0A:[F"~>
+endstream
+endobj
 21 0 obj
+<< /Type /Page
+/Parent 1 0 R
+/MediaBox [ 0 0 612 792 ]
+/Resources 3 0 R
+/Contents 20 0 R
+>>
+endobj
+23 0 obj
 <<
  /Title (\376\377\0\61\0\40\0\101\0\142\0\157\0\165\0\164\0\40\0\164\0\150\0\151\0\163\0\40\0\104\0\157\0\143\0\165\0\155\0\145\0\156\0\164)
- /Parent 20 0 R
- /Next 22 0 R
+ /Parent 22 0 R
+ /Next 24 0 R
  /A 9 0 R
 >> endobj
-22 0 obj
+24 0 obj
 <<
- /Title (\376\377\0\62\0\40\0\101\0\142\0\157\0\165\0\164\0\40\0\164\0\150\0\145\0\40\0\104\0\145\0\155\0\157\0\163)
- /Parent 20 0 R
- /Prev 21 0 R
- /Next 23 0 R
+ /Title (\376\377\0\62\0\40\0\101\0\142\0\157\0\165\0\164\0\40\0\164\0\150\0\145\0\40\0\104\0\145\0\155\0\157)
+ /Parent 22 0 R
+ /Prev 23 0 R
+ /Next 25 0 R
  /A 11 0 R
 >> endobj
-23 0 obj
+25 0 obj
 <<
  /Title (\376\377\0\63\0\40\0\123\0\145\0\164\0\164\0\151\0\156\0\147\0\40\0\171\0\157\0\165\0\162\0\40\0\103\0\114\0\101\0\123\0\123\0\120\0\101\0\124\0\110)
- /Parent 20 0 R
- /Prev 22 0 R
- /Next 24 0 R
+ /Parent 22 0 R
+ /Prev 24 0 R
+ /Next 26 0 R
  /A 13 0 R
 >> endobj
-24 0 obj
+26 0 obj
 <<
  /Title (\376\377\0\64\0\40\0\111\0\156\0\144\0\145\0\170\0\151\0\156\0\147\0\40\0\106\0\151\0\154\0\145\0\163)
- /Parent 20 0 R
- /Prev 23 0 R
- /Next 25 0 R
+ /Parent 22 0 R
+ /Prev 25 0 R
+ /Next 27 0 R
  /A 15 0 R
 >> endobj
-25 0 obj
+27 0 obj
 <<
  /Title (\376\377\0\65\0\40\0\101\0\142\0\157\0\165\0\164\0\40\0\164\0\150\0\145\0\40\0\143\0\157\0\144\0\145\0\56\0\56\0\56)
- /Parent 20 0 R
- /Prev 24 0 R
+ /Parent 22 0 R
+ /Prev 26 0 R
  /A 17 0 R
 >> endobj
-26 0 obj
+28 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F3
 /BaseFont /Helvetica-Bold
 /Encoding /WinAnsiEncoding >>
 endobj
-27 0 obj
+29 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F5
 /BaseFont /Times-Roman
 /Encoding /WinAnsiEncoding >>
 endobj
-28 0 obj
+30 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F1
 /BaseFont /Helvetica
 /Encoding /WinAnsiEncoding >>
 endobj
-29 0 obj
+31 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F9
 /BaseFont /Courier
 /Encoding /WinAnsiEncoding >>
 endobj
-30 0 obj
+32 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F2
 /BaseFont /Helvetica-Oblique
 /Encoding /WinAnsiEncoding >>
 endobj
-31 0 obj
+33 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F7
@@ -176,19 +191,19 @@ endobj
 endobj
 1 0 obj
 << /Type /Pages
-/Count 2
-/Kids [6 0 R 19 0 R ] >>
+/Count 3
+/Kids [6 0 R 19 0 R 21 0 R ] >>
 endobj
 2 0 obj
 << /Type /Catalog
 /Pages 1 0 R
- /Outlines 20 0 R
+ /Outlines 22 0 R
  /PageMode /UseOutlines
  >>
 endobj
 3 0 obj
 << 
-/Font << /F3 26 0 R /F5 27 0 R /F1 28 0 R /F9 29 0 R /F2 30 0 R /F7 31 0 R >> 
+/Font << /F3 28 0 R /F5 29 0 R /F1 30 0 R /F9 31 0 R /F2 32 0 R /F7 33 0 R >> 
 /ProcSet [ /PDF /ImageC /Text ] >> 
 endobj
 9 0 obj
@@ -212,60 +227,62 @@ endobj
 15 0 obj
 <<
 /S /GoTo
-/D [19 0 R /XYZ 85.0 375.198 null]
+/D [19 0 R /XYZ 85.0 295.198 null]
 >>
 endobj
 17 0 obj
 <<
 /S /GoTo
-/D [19 0 R /XYZ 85.0 209.264 null]
+/D [21 0 R /XYZ 85.0 659.0 null]
 >>
 endobj
-20 0 obj
+22 0 obj
 <<
- /First 21 0 R
- /Last 25 0 R
+ /First 23 0 R
+ /Last 27 0 R
 >> endobj
 xref
-0 32
+0 34
 0000000000 65535 f 
-0000005712 00000 n 
-0000005777 00000 n 
-0000005869 00000 n 
+0000006466 00000 n 
+0000006538 00000 n 
+0000006630 00000 n 
 0000000015 00000 n 
 0000000071 00000 n 
-0000000777 00000 n 
-0000000897 00000 n 
-0000000950 00000 n 
-0000006003 00000 n 
-0000001085 00000 n 
-0000006066 00000 n 
-0000001221 00000 n 
-0000006132 00000 n 
-0000001357 00000 n 
-0000006198 00000 n 
-0000001492 00000 n 
-0000006264 00000 n 
-0000001628 00000 n 
-0000003931 00000 n 
-0000006330 00000 n 
-0000004039 00000 n 
-0000004242 00000 n 
-0000004436 00000 n 
-0000004672 00000 n 
-0000004861 00000 n 
-0000005050 00000 n 
-0000005163 00000 n 
-0000005273 00000 n 
-0000005381 00000 n 
-0000005487 00000 n 
-0000005603 00000 n 
+0000000782 00000 n 
+0000000902 00000 n 
+0000000955 00000 n 
+0000006764 00000 n 
+0000001090 00000 n 
+0000006827 00000 n 
+0000001227 00000 n 
+0000006893 00000 n 
+0000001363 00000 n 
+0000006959 00000 n 
+0000001498 00000 n 
+0000007025 00000 n 
+0000001634 00000 n 
+0000004020 00000 n 
+0000004128 00000 n 
+0000004691 00000 n 
+0000007089 00000 n 
+0000004799 00000 n 
+0000005002 00000 n 
+0000005190 00000 n 
+0000005426 00000 n 
+0000005615 00000 n 
+0000005804 00000 n 
+0000005917 00000 n 
+0000006027 00000 n 
+0000006135 00000 n 
+0000006241 00000 n 
+0000006357 00000 n 
 trailer
 <<
-/Size 32
+/Size 34
 /Root 2 0 R
 /Info 4 0 R
 >>
 startxref
-6381
+7140
 %%EOF

Modified: lucene/dev/branches/realtime_search/lucene/docs/demo2.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/demo2.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/demo2.html (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/demo2.html Tue Feb 22 01:00:39 2011
@@ -129,11 +129,8 @@ document.write("Last Published: " + docu
 <div class="menuitem">
 <a href="api/core/index.html">Core</a>
 </div>
-<div class="menuitem">
-<a href="api/demo/index.html">Demo</a>
-</div>
-<div onclick="SwitchMenu('menu_1.1.3.4', 'skin/')" id="menu_1.1.3.4Title" class="menutitle">Contrib</div>
-<div id="menu_1.1.3.4" class="menuitemgroup">
+<div onclick="SwitchMenu('menu_1.1.3.3', 'skin/')" id="menu_1.1.3.3Title" class="menutitle">Contrib</div>
+<div id="menu_1.1.3.3" class="menuitemgroup">
 <div class="menuitem">
 <a href="api/contrib-ant/index.html">Ant</a>
 </div>
@@ -147,6 +144,9 @@ document.write("Last Published: " + docu
 <a href="api/contrib-benchmark/index.html">Benchmark</a>
 </div>
 <div class="menuitem">
+<a href="api/contrib-demo/index.html">Demo</a>
+</div>
+<div class="menuitem">
 <a href="api/contrib-highlighter/index.html">Highlighter</a>
 </div>
 <div class="menuitem">
@@ -251,9 +251,6 @@ document.write("Last Published: " + docu
 <li>
 <a href="#Searching Files">Searching Files</a>
 </li>
-<li>
-<a href="#The Web example...">The Web example...</a>
-</li>
 </ul>
 </div>
 
@@ -275,9 +272,9 @@ how to use Lucene in their applications.
 <div class="section">
 <p>
 Relative to the directory created when you extracted Lucene or retrieved it from Subversion, you
-should see a directory called <span class="codefrag">src</span> which in turn contains a directory called
-<span class="codefrag">demo</span>.  This is the root for all of the Lucene demos.  Under this directory is
-<span class="codefrag">org/apache/lucene/demo</span>.  This is where all the Java sources for the demos live.
+should see a directory called <span class="codefrag">lucene/contrib/demo/</span>.  This is the root for the Lucene
+demo.  Under this directory is <span class="codefrag">src/java/org/apache/lucene/demo/</span>.  This is where all
+the Java sources for the demo live.
 </p>
 <p>
 Within this directory you should see the <span class="codefrag">IndexFiles.java</span> class we executed earlier.
@@ -286,94 +283,107 @@ Bring it up in <span class="codefrag">vi
 </div>
 
 
-<a name="N10037"></a><a name="IndexFiles"></a>
+<a name="N10034"></a><a name="IndexFiles"></a>
 <h2 class="boxed">IndexFiles</h2>
 <div class="section">
 <p>
-As we discussed in the previous walk-through, the <a href="api/demo/org/apache/lucene/demo/IndexFiles.html">IndexFiles</a> class creates a Lucene
+As we discussed in the previous walk-through, the <a href="api/contrib-demo/org/apache/lucene/demo/IndexFiles.html">IndexFiles</a> class creates a Lucene
 Index. Let's take a look at how it does this.
 </p>
 <p>
-The first substantial thing the <span class="codefrag">main</span> function does is instantiate <a href="api/core/org/apache/lucene/index/IndexWriter.html">IndexWriter</a>.  It passes the string
-"<span class="codefrag">index</span>" and a new instance of a class called <a href="api/core/org/apache/lucene/analysis/standard/StandardAnalyzer.html">StandardAnalyzer</a>. 
-The "<span class="codefrag">index</span>" string is the name of the filesystem directory where all index information
-should be stored.  Because we're not passing a full path, this will be created as a subdirectory of
-the current working directory (if it does not already exist). On some platforms, it may be created
-in other directories (such as the user's home directory).
+The <span class="codefrag">main()</span> method parses the command-line parameters, then in preparation for
+instantiating <a href="api/core/org/apache/lucene/index/IndexWriter.html">IndexWriter</a>, opens a 
+<a href="api/core/org/apache/lucene/store/Directory.html">Directory</a> and instantiates
+<a href="api/module-analysis-common/org/apache/lucene/analysis/standard/StandardAnalyzer.html">StandardAnalyzer</a> and
+<a href="api/core/org/apache/lucene/index/IndexWriterConfig.html">IndexWriterConfig</a>.
+</p>
+<p>
+The value of the <span class="codefrag">-index</span> command-line parameter is the name of the filesystem directory
+where all index information should be stored.  If <span class="codefrag">IndexFiles</span> is invoked with a 
+relative path given in the <span class="codefrag">-index</span> command-line parameter, or if the <span class="codefrag">-index</span>
+command-line parameter is not given, causing the default relative index path "<span class="codefrag">index</span>"
+to be used, the index path will be created as a subdirectory of the current working directory
+(if it does not already exist).  On some platforms, the index path may be created in a different
+directory (such as the user's home directory).
+</p>
+<p>
+The <span class="codefrag">-docs</span> command-line parameter value is the location of the directory containing
+files to be indexed.
+</p>
+<p>
+The <span class="codefrag">-update</span> command-line parameter tells <span class="codefrag">IndexFiles</span> not to delete the
+index if it already exists.  When <span class="codefrag">-update</span> is not given, <span class="codefrag">IndexFiles</span> will
+first wipe the slate clean before indexing any documents.
 </p>
 <p>
-The <a href="api/core/org/apache/lucene/index/IndexWriter.html">IndexWriter</a> is the main
-class responsible for creating indices.  To use it you must instantiate it with a path that it can
-write the index into.  If this path does not exist it will first create it.  Otherwise it will
-refresh the index at that path.  You can also create an index using one of the subclasses of <a href="api/core/org/apache/lucene/store/Directory.html">Directory</a>.  In any case, you must also pass an
-instance of <a href="api/core/org/apache/lucene/analysis/Analyzer.html">org.apache.lucene.analysis.Analyzer</a>.
+Lucene <a href="api/core/org/apache/lucene/store/Directory.html">Directory</a>s are used by the
+<span class="codefrag">IndexWriter</span> to store information in the index.  In addition to the 
+<a href="api/core/org/apache/lucen/store/FSDirectory.html">FSDirectory</a> implementation we are using,
+there are several other <span class="codefrag">Directory</span> subclasses that can write to RAM, to databases, etc.
 </p>
 <p>
-The particular <a href="api/core/org/apache/lucene/analysis/Analyzer.html">Analyzer</a> we
-are using, <a href="api/core/org/apache/lucene/analysis/standard/StandardAnalyzer.html">StandardAnalyzer</a>, is
-little more than a standard Java Tokenizer, converting all strings to lowercase and filtering out
-stop words and characters from the index.  By stop words and characters I mean common language
-words such as articles (a, an, the, etc.) and other strings that may have less value for searching
-(e.g. <b>'s</b>) .  It should be noted that there are different rules for every language, and you
-should use the proper analyzer for each.  Lucene currently provides Analyzers for a number of
-different languages (see the <span class="codefrag">*Analyzer.java</span> sources under <a href="http://svn.apache.org/repos/asf/lucene/dev/trunk/modules/analysis/common/src/java/org/apache/lucene/analysis/">modules/analysis/common/src/java/org/apache/lucene/analysis</a>).
+Lucene <a href="api/core/org/apache/lucene/analysis/Analyzer.html">Analyzer</a>s are processing pipelines
+that break up text into indexed tokens, a.k.a. terms, and optionally perform other operations on these
+tokens, e.g. downcasing, synonym insertion, filtering out unwanted tokens, etc.  The <span class="codefrag">Analyzer</span>
+we are using is <span class="codefrag">StandardAnalyzer</span>, which creates tokens using the Word Break rules from the
+Unicode Text Segmentation algorithm specified in <a href="http://unicode.org/reports/tr29/">Unicode
+Standard Annex #29</a>; converts tokens to lowercase; and then filters out stopwords.  Stopwords are
+common language words such as articles (a, an, the, etc.) and other tokens that may have less value for
+searching.  It should be noted that there are different rules for every language, and you should use the
+proper analyzer for each.  Lucene currently provides Analyzers for a number of different languages (see
+the <span class="codefrag">*Analyzer.java</span> sources under 
+<a href="http://svn.apache.org/repos/asf/lucene/dev/trunk/modules/analysis/common/src/java/org/apache/lucene/analysis/">modules/analysis/common/src/java/org/apache/lucene/analysis</a>).
 </p>
 <p>
-Looking further down in the file, you should see the <span class="codefrag">indexDocs()</span> code.  This recursive
-function simply crawls the directories and uses <a href="api/demo/org/apache/lucene/demo/FileDocument.html">FileDocument</a> to create <a href="api/core/org/apache/lucene/document/Document.html">Document</a> objects.  The <a href="api/core/org/apache/lucene/document/Document.html">Document</a> is simply a data object to
-represent the content in the file as well as its creation time and location.  These instances are
-added to the <span class="codefrag">indexWriter</span>.  Take a look inside <a href="api/demo/org/apache/lucene/demo/FileDocument.html">FileDocument</a>.  It's not particularly
-complicated.  It just adds fields to the <a href="api/core/org/apache/lucene/document/Document.html">Document</a>.
+The <span class="codefrag">IndexWriterConfig</span> instance holds all configuration for <span class="codefrag">IndexWriter</span>.  For
+example, we set the <span class="codefrag">OpenMode</span> to use here based on the value of the <span class="codefrag">-update</span>
+command-line parameter.
 </p>
 <p>
-As you can see there isn't much to creating an index.  The devil is in the details.  You may also
-wish to examine the other samples in this directory, particularly the <a href="api/demo/org/apache/lucene/demo/IndexHTML.html">IndexHTML</a> class.  It is a bit more
-complex but builds upon this example.
+Looking further down in the file, after <span class="codefrag">IndexWriter</span> is instantiated, you should see the
+<span class="codefrag">indexDocs()</span> code.  This recursive function crawls the directories and creates
+<a href="api/core/org/apache/lucene/document/Document.html">Document</a> objects.  The 
+<span class="codefrag">Document</span> is simply a data object to represent the text content from the file as well as
+its creation time and location.  These instances are added to the <span class="codefrag">IndexWriter</span>.  If
+the <span class="codefrag">-update</span> command-line parameter is given, the <span class="codefrag">IndexWriter</span> 
+<span class="codefrag">OpenMode</span> will be set to <span class="codefrag">OpenMode.CREATE_OR_APPEND</span>, and rather than
+adding documents to the index, the <span class="codefrag">IndexWriter</span> will <strong>update</strong> them
+in the index by attempting to find an already-indexed document with the same identifier (in our
+case, the file path serves as the identifier); deleting it from the index if it exists; and then
+adding the new document to the index.
 </p>
 </div>
 
 
-<a name="N100A0"></a><a name="Searching Files"></a>
+<a name="N100DB"></a><a name="Searching Files"></a>
 <h2 class="boxed">Searching Files</h2>
 <div class="section">
 <p>
-The <a href="api/demo/org/apache/lucene/demo/SearchFiles.html">SearchFiles</a> class is
-quite simple.  It primarily collaborates with an <a href="api/core/org/apache/lucene/search/IndexSearcher.html">IndexSearcher</a>, <a href="api/core/org/apache/lucene/analysis/standard/StandardAnalyzer.html">StandardAnalyzer</a>
-(which is used in the <a href="api/core/org/apache/lucene/demo/IndexFiles.html">IndexFiles</a> class as well) and a
-<a href="api/core/org/apache/lucene/queryParser/QueryParser.html">QueryParser</a>.  The
+The <a href="api/contrib-demo/org/apache/lucene/demo/SearchFiles.html">SearchFiles</a> class is
+quite simple.  It primarily collaborates with an 
+<a href="api/core/org/apache/lucene/search/IndexSearcher.html">IndexSearcher</a>, 
+<a href="api/modules-analysis-common/org/apache/lucene/analysis/standard/StandardAnalyzer.html">StandardAnalyzer</a> (which is used in the
+<a href="api/contrib-demo/org/apache/lucene/demo/IndexFiles.html">IndexFiles</a> class as well)
+and a <a href="api/core/org/apache/lucene/queryParser/QueryParser.html">QueryParser</a>.  The
 query parser is constructed with an analyzer used to interpret your query text in the same way the
-documents are interpreted: finding the end of words and removing useless words like 'a', 'an' and
-'the'.  The <a href="api/core/org/apache/lucene/search/Query.html">Query</a> object contains
-the results from the <a href="api/core/org/apache/lucene/queryParser/QueryParser.html">QueryParser</a> which is passed to
-the searcher.  Note that it's also possible to programmatically construct a rich <a href="api/core/org/apache/lucene/search/Query.html">Query</a> object without using the query
+documents are interpreted: finding word boundaries, downcasing, and removing useless words like
+'a', 'an' and 'the'.  The <a href="api/core/org/apache/lucene/search/Query.html">Query</a>
+object contains the results from the
+<a href="api/core/org/apache/lucene/queryParser/QueryParser.html">QueryParser</a> which is passed
+to the searcher.  Note that it's also possible to programmatically construct a rich 
+<a href="api/core/org/apache/lucene/search/Query.html">Query</a> object without using the query
 parser.  The query parser just enables decoding the <a href="queryparsersyntax.html">Lucene query
-syntax</a> into the corresponding <a href="api/core/org/apache/lucene/search/Query.html">Query</a> object. Search can be executed in 
-two different ways: 
-<ul>
-
-<li>Streaming: A <a href="api/core/org/apache/lucene/search/Collector.html">Collector</a> subclass
-simply prints out the document ID and score for each matching document.</li>
-
-<li>Paging: Using a <a href="api/core/org/apache/lucene/search/TopScoreDocCollector.html">TopScoreDocCollector</a>
- the search results are printed in pages, sorted by score (i. e. relevance).</li>
-
-</ul>  
-
+syntax</a> into the corresponding <a href="api/core/org/apache/lucene/search/Query.html">Query</a>
+object.
 </p>
-</div>
-
-
-<a name="N100E2"></a><a name="The Web example..."></a>
-<h2 class="boxed">The Web example...</h2>
-<div class="section">
 <p>
 
-<a href="demo3.html">read on&gt;&gt;&gt;</a>
-
+<span class="codefrag">SearchFiles</span> uses the <span class="codefrag">IndexSearcher.search(query,n)</span> method that returns
+<a href="api/core/org/apache/lucene/search/TopDocs.html">TopDocs</a> with max <span class="codefrag">n</span> hits.
+The results are printed in pages, sorted by score (i.e. relevance).
 </p>
 </div>
 
-
 </div>
 <!--+
     |end content

Modified: lucene/dev/branches/realtime_search/lucene/docs/demo2.pdf
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/demo2.pdf?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/demo2.pdf (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/demo2.pdf Tue Feb 22 01:00:39 2011
@@ -5,10 +5,10 @@
 /Producer (FOP 0.20.5) >>
 endobj
 5 0 obj
-<< /Length 615 /Filter [ /ASCII85Decode /FlateDecode ]
+<< /Length 570 /Filter [ /ASCII85Decode /FlateDecode ]
  >>
 stream
-Gau`Q9okbt&A@ZcI*<Ykos`nIUlEl=V5amN*k"3CDuqN*WI`mm^FpE>44-[e.;KFgg#JKGcQBKRKDR5(KL#b#6\,#?)B`u-0L4HL6.Cr%L*.3SLelrCYrX7HY3s)gaKV.<4LD)f4M5dlF]'$TK4!,"41*J=8QC0DIY7Fm<BNr\]Z6iGZYXZWgLEDchet6bAB=RU+m09nOH#)tR8GUii!-dlO0X"2Ao]7"B(*:*$jnHgGB'oA/PY(t/bHmP;dD8\C?in_#8gbC_l1nJGJfO_r*eLZM@?r:II#Ei[uH<ujBa;TSTW"siQYSn#*'OrI00j4.fkP6PTqV4.tMX;T[T\cFS5VS>UWM)ZZTbP]'rr76BD^,+W9>c2`e-qBDnsTeEaOkqqL^6gO?u-&$3a*=E=N-aFhaDp8iHf0kjrn8%6g:X?i1D813hISi[B)*ng%.m[eRfTC,4WG<ihgVfShR2Rh8RhL4p;pYYaqNJ#!SL=eF!,7,[b2R3Pn&e9j%LYugLmV<?$PX7&LP&[\ti9ji=JqJkS#CiMps%IFV)u#Nq+ri[4&/#JlI\"'Q><@7H?4u:XCirrnp5/;h`MtI0Yd%sSX'1p(PsIq=5FMA&K)~>
+Gau`P9lHd\&A@Zck*R4Lq@gb$aYm%t9%>C^Hg'mKJeQL/g_sk<s*i3_YnL,0:G!QRB9-]f]tq$MK$,_Jaq9A=+5m-^"W.^M!Gl*EEPE90N*$o_nd+uJePhnOl2m8N7Wr]igL[DYnC!`jZmdd9J#Gm)cq\d3;p>LDJ`Pr=+(6eZYI+/<C^[#M6SUT.D@$k8epMR9#`_HoVaB_)W)o=)K:I?kPqU;(i?T!6;)lQmaMKZ:P!2hI:!ml2o\S8hY$4o8boBLZ_8l'OmctU23L4/;id7;Z+iA<WHhF&Den&Y*YEY$l/K.=Tjc;!G`#Q&]JH\1e!KS[m'.J6.!oNlUB5(T8qVrV:.FJY)ee`+2dgJ/C5sM3!j@Du"fQec*n*<#9DqhS_DpLAMrJ7iu=biVY/OIB&*rJ-9c[2QfP8.YWE..^t%;[1"S%6<.n1"a9LD`.s&:u3k_@l)67T=n8YRc0el[JQU=XB"N._5%<0<r+.Tn&NTNSirtJ#5=BXd`k9W?;[JN'i@5InlW]m@E+CYGq%m[^rO2iJMoEE`H*L%(R;fX%&KnPp8ft5;Fun9`~>
 endstream
 endobj
 6 0 obj
@@ -26,7 +26,6 @@ endobj
 10 0 R
 12 0 R
 14 0 R
-16 0 R
 ]
 endobj
 8 0 obj
@@ -70,119 +69,101 @@ endobj
 >>
 endobj
 16 0 obj
-<< /Type /Annot
-/Subtype /Link
-/Rect [ 102.0 446.366 206.972 434.366 ]
-/C [ 0 0 0 ]
-/Border [ 0 0 0 ]
-/A 17 0 R
-/H /I
->>
-endobj
-18 0 obj
-<< /Length 2590 /Filter [ /ASCII85Decode /FlateDecode ]
+<< /Length 2391 /Filter [ /ASCII85Decode /FlateDecode ]
  >>
 stream
-Gatm>D3*F0%/ui*@I-YAiD+#II`oIu[WP\L?n]c$%(gr73D-$rYqk!-HMdB1r(9"JH:*GhG:1G*aG8hDMWt(cnbme(pVLRr.eB!uq&KWiq&T@5bk(JPF+<uN&)LdW1Z(jb#_#7Jq>3(+=g3iI/\K-C08o`#ipKP+"m1O3G2[e["\=/nJ_+auQLK4[XUj810*Cpj]+%t!04-rDVOj+H?;-8qeHT'(HL&&2qEZY)LL-B[`3LX+e;7(h&7o<(#WlUr,%89][+"'U&g&[*BiU#&Q3r%f7V\K>nI]]hWnHb[-<."m\Nl<"`EniLa4n-c*-f$)/S'^0^2%b?f,J^+h]R(86DI=leO)gNp+mKXAoHi>*,`hql=kP)\jkEFfhVJ1[OGG-OE9%*6,aqgZ52Ok+RrZiKYQUrNY+7-661bL!m\(QA9Trlj&O>$hKT.KYbcmQF]B*Mp?G>V*+,kO\3uWX=SVDgaIF3m.u'hp$^3;?@hqi0Il/5q)G.jk5O@;6Ogj2H:<i$[g0P5(B5Y_/!nr<[D?,1]SD9'uOJN%Nr$i'#js9<M+PLY-L<rip$"]88]Z/>%=b7'/;U)Q[T5)Vlo(LkR3#&d![=eNJY=lfA>HJCal@&8KJf"ShDlf'=Y#meg9U)RNW[Z:,PsFX(laHDZ0\WqTh7ZrsJ8O.9^cgcN9'>6#9E0Ylg?)VbH^X=C8^M.Xb#MSc=]YQl"]62B36\<^L)7%\&GnXqcM'<?b5?,H=-0ZJYa<;$<XK'4%N$n^)(B-,q$O+qRis:`]s;$*)IUId1WDpB=m=`_5Os1TmYY&/]?e817N%,_N2p>IaqXr4!(&.7U6$"D.308dVI]cR_JIMVZ@K%]h*4FqeCb@7n9obo[`Z.E0oO[6bG[<`K!R\TObKad?S)[]2_9Mb0=L$IY;#$.)=^;Z%H0@aFWlII6^2*p,N%gq^=l,]3Dpc7=rYC/>=K2>I$.P>%+9s.o,ZKXi!?\&)d22sEPCO
 ]-$(&Q\F:</IXs2Rq+!O*(.t:gO4P51s0KF0OC,&fL-EAd8'?ke8_*pM6od72Q*YF"^l9eAd2s:0N&.&&\Kg%OZ);j6#ec5!ntrEXi@H!0I+7.$<J)S`f6uC4gGb-ufYZ&#1`*aC^g;l['\nSPk694=38",rM^+!6SN*f2$EIo$af<WA"/cRmX>(o'#n8NHV<61t]=$^QF\,nhL9?h8Q6[&*o"\,N>=q<sZY7'c\1Y:MV3cg@l[%ui%pIO9GE#C\[7B^K`D9U`"(oXZ[Ao\$gfN+K/F8fL,!['SY45X->]0D\5tWPO8o^F)K"2<]*-Xo&hcPm*WO_qG]m3oSioqNd,RL5]-q%H>i^a"XKkQ`XDF,`[DQn@9Na_*ibhTfT>5[:YVl&\Z>k(eD!k%B\>(<Yekq/Hld$PebpS`@an;+8GE0Suti9s+[gWQJ5G.8ZS1j]ukYYq<d76V#f'GB.)X+01fV,PgC8c1'hqVltCm?@s2A&6XYO1`kDPfSrmdN;bG!4?S&@*9](0-r[!c)Ln+?@ZH',Xm*D<W2Coq<'-l=G=ZZ#WGfErT_COmX[Sc'2;^J'd0<S!'ns)k5\%hg&p8oDeRpk/eDq>f<@ECCBV,ciDPeW'hq94^*q&C8)'H&B[N(W#Ba`X*E?7a`rbEWDY70IBo?/4T]*etW3pE8KDe2Aqa4j#W5[sO5WiR-:fucrXr#Xl1&6U`TFE2ZDENn8LcRf6i1jK7njkMHH\*_f,t6OHE*8%nU@15rciNBl1tKW0QA9P+`;WoN*(A3&@LGK]R`*KjiO'&9!sDN\G8q%0$bWE71sPF'DpHXG.L2f(:tnH3;rr'M(_CMQ.+hi#jmRrZ,o6T`-CMJF!caPQ&+$_H8Z#D/D2jFlnd)XX9(,k@MdY?lJoT83<7(T<7`?PsoGp&)`n3%b$BF=Z&;@t-]2+?Q_[nNn[L)OgR68tVAugP.KDI_;-JT2Td\eI2V\oIlfM<k)>-!^YPZ4
 ,WPp`7S.?a+qla&8g,I\HR/@:6?lruTGQN[p^&Pg'aJ^t%M"e_)u>[Jf<He...@e>-R!bd*b8aHK%5o=^<^/`3$/U.(M"4O@EGSg\7.eN[M>4m$Q>9Ho"om=*Kc[C7d:YmMh(*C<#m^I<bZ<O\K=(j2DZ?0ibliVG2![4<*pA~>
+Gatm=h/D%+&:aF]+m`bld*NEu]sjkEMA?B(2'2=mm"(I9S#n5fPiO+elZ`30FHe6-7>Ck7.-ln;^UsC!OhP*QIU+Q)=kG!W,MTWk^RjK8IsjD=/5'i^kmtOVYSOK<Cb...@DnRE>Y6Ar)%PTXn@X1bKH2<!U+Y9R?%"+`TY@=*t]<%Q^:R_Qa4R4TkhgGUc>`.IIYe:5T1P*q#sE07V"'cb>g8/<^^+<NO,
 hr1Atto-+GgrVjh$\Il*!W!1=4Pr^2@A4Q9B-:9J^gQVbd7b>"8&'1G_eo)p60,6oR'nt5$nqduC."2l9_O=l&^$2EH2\T*A_`m:1/[QP-0SXaEdu?D0>l_F_PJ<`>3-2H@%bF]1\^lp3@5Q#a+=JUY<jQo.37&]J?"2,JrqPdKoir4uh*tm/?LB'G-4Ji:TB`*31BWFe:]mJJ*n&i6,*3PIKKf>lIDC@>n3qFS<TNiN>RD%]'\3E^5m]4Fm10kWDGH;fkA<KEOC9)e_gO\Z1R5]!=n_D>mduLC_0"Q^_9$e0j#`ZI`7CFZ/t/)-)#,?!.Qeo8BBAAOJO..qW35tdeE4t#$?\\pO/4H3s,$h.LGuCRpc!?_^D%taZRtIu#2J.,h&#Y;ACC9:/0XESUJ)Y'!Gd&s!=O.0fm#<*]h9fJEM/eF`o#p(+?Z"?:U!@b9fmC2jC?DWeK8W:\A:JE-\;H<)R^bD;88G1c6Y*&FPU"D*)-'9W='#fM]HHfe[=@*!K$#a>3`XNZ0@dPk;YC@GeeU5?ugWaBqg.U9NY;.gc([h2lt.o;sYk=5`b_:F'-C6M*0UXMbq5017%_Bfe1N<<l&`02&kI*FbjIH%a:pM,VTD[S^%`5bhOq1C2Gpl9_)7_.E-?BLF9(8Bjif2Hdi[PH@4*1K4Wt,C?.biS[553r[`rtnMMMnh_=(^9Zm[^R@4nL$Sa?ud%7pUM)D.Em>bV]iAu?U[#-?dR0,BfQD`)jHS1!l;g@*PBb9nU2NSeU6!O9$8PPDY8S'ZtrXN$bQFXU&N[BJ%?CY;N!GB";Oa.9)VO#^NI:P:o%9%!PA?[+f<RY0uKq(+DMYem922RgfO@&B[+WgDtg<uh#7_Ieb2KtMJJk9k<l.W<["/%rN8SSBY3Afi:qAnHq9MI\qXta<*Tu19a1FJTF:^Y,g&'_UK*>W<1cn]aGQfCEGJ:qF;MqrD7'%"!Q(i)!O=%:%iQdctt7]6B0^,S
 g*U<"13;j)-d)ab12oBD\G.?=S2eK;t3J:M+/4g:m\W9O*@"?8S!pZEdV%+V:B,EdNo\N+^G$r_#=DiP;sF7?drnOA[$op`Mi_H]<N9-LkSK&Jh+KZlk4;3n(Gf09"Y_;2f`]IEQ0N7[#se)1(_+GWeZ%9ZE=>OWk=$tZ<;hsSmg((:Bc\=Q('4"GDXim>3Irb8O%CE6hSi\7&#@\nQrUTJE:+VO1aqsFs'IrIX-s7Xb[d%-8Aok&'qq^fbt8a(BM=Z2t&I@7K'?"Q*,Isg_flIDoTcEMBQGIH$RV[*gRDR0d5'+I)HI@]`?bRb#n'mY=ge#I^A%kgOkG>52p;)=2.h\fJE[Y&#=*TPlX6FBtRb>%f^"g<>p-`]@@rE#JZ=N`MfU=m.DCC[\pETipCh1&TmEB4~>
 endstream
 endobj
-19 0 obj
+17 0 obj
 << /Type /Page
 /Parent 1 0 R
 /MediaBox [ 0 0 612 792 ]
 /Resources 3 0 R
-/Contents 18 0 R
+/Contents 16 0 R
 >>
 endobj
-20 0 obj
-<< /Length 2028 /Filter [ /ASCII85Decode /FlateDecode ]
+18 0 obj
+<< /Length 2990 /Filter [ /ASCII85Decode /FlateDecode ]
  >>
 stream
-Gatm<gN)%,&:N/3n4iUM%.Seg6Y:A<dr^aJ;QH#Ge9uj<84#WT$:%d<^V7mLa9<#4Icu#m$P]ku4kMoEJ2cf50C-T<L$.g\p\c:WM<i*"%"H0nrI!]1.7kQ%SB^':ilueS\rIcVLMtbuL"jjmiQ$$9R8HXe2g!UUkO4=6<41eV's20Fn1Tu?V.@=:7doP5aPD^pBte5\ZH67gqNhmt\!Q1(q8ZY<2DZ=@,Wm%F.)^=9m4Oq[^[pu)gW4]ejRf)VVeR,ioGQLQo6AA`9Z%+_9EV[=9j+,D@l#X+Q`KFgK]DE=&GdYFI,/LC($tpjaOT[smH$;fH8IYS,N?rqkFu?p>(40JC)T[02cB0-Ad$ERM17FiD5t82!l:T*iE/9;j':#2W@W!'*1!UYj:&^f.g/bFn5n3A01=S8=B-T0!\_T-NE1<%[b,t[23g0Ngl/c+f[fpIm9m`l5uSIAXm(4QZg3bp,u],#fS)6\FUt(d6KAPqoYeo#r!fip$'?Wo83/(l$a-qm2*We<cBTUB?IlCjiktbrRT?u-pC`rG$<EP!qFS4C.ER0DGJ5SoYEILS=kei\8r5L!MF4&oR;nilTF`>uWBUt37*H#q+6PF`j?pUKQrF.Sq2rggk=nOE<b):&Ns"7?d*,1U^GW%BOB"8G=Gb(ZJ=[R.Z$)koS*8rk18g7B:,,ho(_CUL=4Iq/Ht`*L',@^52q=96G$Rm0<1E67Q[$Vbe5jD#b"IF^re9Ao:eUtf&k8h:FJ@+q=-gq[4[&:LhBYQ?d2S=EO93WE!KQQk\dt`<RIa$Tn3[TFYNnt+&b[MNb*$ah7;>3kqU%jB)icj]8<*AtaR5r2S#41-XsJ"-'\:'(5f(r1I64"ZOu,hf^hNh(T%Et&gamRf\T@+Erpek0Ptg=.`#k6R1tj)%UeTinU!>@j1cHZ\cqG7&L_.4-<9ANZSQh7RfO[c\Kc*F^3$)?rHkKW$Q0(Bbnkrr\FM.psU=r)+p\%+
 pEPq0I+g^7J;=XgS>c4a1U`1J.]5XD%2(Ar<cs...@5>3\4/'V)GhV&$UQ*t/1^_+8]cnI"%h)eDfN,?*7Ci[;+-91r=5NCJ^-K<qH2PE4O6rR#)8@h%AbRHW-&A0OnS:q\d3RL9FY$)0]Z_$KS+5)d]n2V_[Q\;.tBD/C(:jB'1,>L9nT#R<2`?5fS5P**h'I6W<4Si=/[KAm&C\3i[WHM[CP)JUYg;#3,?=^.=:=J7Hbgo)N^O[r=cHtVCVQ"rEuMd9f!79>E%F43&:3#HoLb%RZ+MPj2l!PB)81&FXg3adI&`IUX$/WMclj)EX*5\ZmV-Q#Zq0ce9B6oi[9;b2s"+glMQo9pNC$BgMOAoQX6E0S[NO\+aqGO<4n\f1H1Ui>7;,XtDufjZp[_3jQ_;+*;XqT:_+l?XaPLfG;hR89PbeE4IM3rKr-fMAg@!haT=$4XK>lIDq:j5#:TUnG*Xdh=AWSt?Iii9iq;2#u0s-*`NqDL?Q&NS[LNF7%(2:^l'1)c0JNXi^A).kSMCeU&a6h-Si7J>@81Eta^)!uetN;%(D;%#/C'-4?L]LKL4$FLM@*K]i&"_ERff(njT-08`:97nss(/7*8[XZ/L8^>!iOP,)BhqN3^rI+O@Ud?"P1!(#=uDoB
 (J%;"*T\J>WFrpf,bR+>Vkon..!KuOPtfj/fEEX(qrKlMO.~>
+Gat%&>EbOK%Xt$WiMq<nbgm1)R-X0=Y,BREF3."dQ%tp4;f1;JSH51$_g&i/IaqhYKE6EMQ"7D'OjqgW:[357](rkIq/PFGG4>7(S(P1971]UkYNMCI+-rL2717'Nl^L+WhQ:Z:5K+#NKdWqgNSR.YnAe\=P($dB[^TB#MgrM;+;@U$W=F-1s"%3cJ>D'oStm>jK[kpHY1H7b[-%4&n_c;t]W"e0oiDGMqMW$"'h<2broYqQJ%HePZ=+JP1\_*!cE"lEC.`>HqNc>'majMY"o@$/Jn9`;EeSUH$9^&-9XrZJfV*YdjI%Enm9;*dT)6^B6ne+4oV*b<;52_4=2)Kd5P"rGaK0$4N>q,nQ?tBmi[Q<b"^4lkQ&oBrG!Hg_[?W4303'H&=GA><`/r*H^uf^_BCt?;c9e!JpI2rX:XL]h:rqXXO4n3dQ@6&5'UgPI$Bj5&$qr!p,\uK']%F?`Re:J94K#5[b.F%%cXM@f6F;)=X]$4aUrkG"/U&>Gk7_i:duY5h7\@[lIdC:dC"][)CcPF`/$s>6hf>\QEm$W]8W",s!kTXrhtV1hm4(OOI?P$*^cRu0Wm:+F>:&ltAc>\c6uMd%T_OZ(_pF9Og/l#3Gu6FbN*MtA,f!35^84JoLonJ/,)VMdG7,KuN?P.VYPmS?h"[M_K<f`QpmlDu6%fj!K")&j9^]HC%,tr/P2kISUiW"H3-B4]kXq.ffG\U8UQ5'qU,.pWNr>?M@TTlVH=J)"CE,f;O.$>CUk:?*3M)=oG^@75Utl]*#H@WC2hc\pfZp!_E'.b=,?+;fliYe"fF,l;oFS5@REh3m;Fh2Vhk.1R;d!a(_tA7fHcmHf$;&'m-uBB_6C!P_DW,;\?6:L8<h2UV*mStTWj3UT4`+4o$:IKZCl.n>;:)%TE8r";W3.[COb\^75,jgPRhS"3?c3-f5=,Rq2d$)i;<M^m+h+da5.Q]lZfXWA>_%&(Z)k^4PdS63(H0=\i[$9
 8,-,:W'!+_8b[]Gcp9KIE>]*6>4>n.SKmmiHi)-Q9d4"N5eaAQbYS$dfC]*)'qK+[=>.b-GQMI9@30"^V<8qOXR(aI;W8>^,.s>uVDAcXO5T[E<TQc!2+dEoG]dtDT%A0TLTS>9819%]p8!^iYepBkrcgZX^-joK?EcfL;!:^Hrb47=*)2fAfk1-j?k^YF>kL%i[.!b>e?].G1mR9Be#'-+'&mV*VAI(JSmU?5_#3^tDES`+i"kF>T<4RdqK^N<pVUj!U@SA*\!"'fA=+C:*.@,&-jRLl0H@89^.ciHp:>8t"8nCQb3$f`^J6Gb<H&H2!g]MHX>;:)"U<Ic=\b%,i)2\c\FYqcO$#o#2WAIg*ra/4g>c5W?VLSFb'E.RCeGj5N$mD=CW8ViOs'nEh$a,a1\GU:2,,$]P.(7Io`3*p:S[?2*95<W-ZN`MV]W!&!T`^t9+bEsKLUHg*h2C:qOSSu`AFR"S9SOMS:_(*/$\0-p?W"3fm5dkd7UsScHXE*HHHBV%9\fk\o`3)KH$?-(0UZp;JhE`+6G47+Itf0eoClk[817F]k7cU?aeX3MmM:Pm;b`^ThJBNlNU6=G(L&VY'4U!EWU<-sl3p*9S_];e1NIep]MMmMW%NTH7-$*74+RJkI3<\6Mijp"Mg(9=K8sDY!9!ZR&-qj>`0I6CY,IFg'Ns:3Z+[rX[iX,e&SD>GO2>013UU\7>+3^S&goiEpKp+u?%)Y:O"Z!rrVZKOmiUZl+W=KsW]'q/6lW<DcN#,e8bLgXiCM8tHClnLpT(d+FdA(8K%Hha>;M(C]15AJE1D--".>&jm4R?Zc9M_1b-Ad(Sj6/*Z+-fY?<2/-K06^[GdGKBA:STf_a?AQ*/Qfh&_'NV8NOj?WcUR;bqN$^1Bqr0.r_"@&TaXa6,3m#E4GAs?sb[jJ`c6O_!=tMme(k:6^*fFcZnct&QcJe<-_bX)Jkm.oG+RF?\PZTFVCBU5*>:KI".`%f-]
 4.au5"b[M?cD]j-s)4i];W6`GkW$aj245Q(*$U-5AU6<S;(`tXOE-,q1m'Tc8M8G9W7eDO*^@h2A;:6QIC,Dg$DdAosd8R1kjBe#/n5d+W1%48U")aZ>$U99brE;XAcVrf[D]^5Qpak92%T_QHqW)OsR8mmC=a=Lh:W@2h`q1`t$J\"lPY3s?if+"D1&#Y0'I8UR;_Ut_h:X)X+1c;kgHO;-t+_-^'4iArPXLUB>AkG!ff/Y(Qf"tA[B^LkLbdtr/M/`oSFm;TL#oUTSH_$`'O1L,g!C7S)#)r9S5X97\k3t@p.\,>$_l,N<KHrs-D5J3b9%k`=2ufNsL#h6bbl?;#2UNhl&`2`n&EOKdQS2lPE+V1j*O3[C-2:TEks.9CccC]BG'f:RMVF!6hh#?ULOhm'%i)-2Rq%m%-And;")Ui)@3<g[$l%fuFusl&:G\DBRR>f>?D=Wj/S$!AJ!]6CQ;!r?F\?=[)Qd49Xi21pBDg:XaW9mC*."E6SksSj8$`-LF=.P[!)pi,$bKp>QQ@'j*+b+]`DfrE5aLlH``9`\CP%B^T#d%'5%8fuF^R+tILfE)#DbcA3Jtq\:S`TX/EJ"@8"F@"inY)DQP75t;L*h:A%?pTHNeJ$hfY6Nmm]^:e3L'om&/E#pVlLOa@lu.K@QWk9]b>4$p\:(MG\&-]XWTkPq:20C9!T\AufMJZ^qoP/m5EG4UqId20_>#kOYH?=;q*`KV/S9\-/)Z^]P\K91@^V%>om*6gFg@[kJClJFP:)/CGUc4FV;ecoI^%=U:Mb\FK)k^,_0,l\(rHLOk@ZL:US"jQ[a"TS2+r!(D[upt?g_FSEMSm.m>IQ)o0Y+j%MZgF]m%/+em5'8VE^W93eA24[TS@LkB]BZoT!!GhGK-1Z_!\(_<BgC6:frEbQFRh;j=J2hORVd8T$/.YA>dO&#4W:@C`48kF[gHg=3%#FTY\[8pH._!t-(_lA.:JGQl``u$=G+d5h1u
 HmJRQ!so#'Ca^"*IW+K)~>
 endstream
 endobj
-21 0 obj
+19 0 obj
 << /Type /Page
 /Parent 1 0 R
 /MediaBox [ 0 0 612 792 ]
 /Resources 3 0 R
-/Contents 20 0 R
+/Contents 18 0 R
 >>
 endobj
-23 0 obj
+21 0 obj
 <<
  /Title (\376\377\0\61\0\40\0\101\0\142\0\157\0\165\0\164\0\40\0\164\0\150\0\145\0\40\0\103\0\157\0\144\0\145)
- /Parent 22 0 R
- /Next 24 0 R
+ /Parent 20 0 R
+ /Next 22 0 R
  /A 9 0 R
 >> endobj
-24 0 obj
+22 0 obj
 <<
  /Title (\376\377\0\62\0\40\0\114\0\157\0\143\0\141\0\164\0\151\0\157\0\156\0\40\0\157\0\146\0\40\0\164\0\150\0\145\0\40\0\163\0\157\0\165\0\162\0\143\0\145)
- /Parent 22 0 R
- /Prev 23 0 R
- /Next 25 0 R
+ /Parent 20 0 R
+ /Prev 21 0 R
+ /Next 23 0 R
  /A 11 0 R
 >> endobj
-25 0 obj
+23 0 obj
 <<
  /Title (\376\377\0\63\0\40\0\111\0\156\0\144\0\145\0\170\0\106\0\151\0\154\0\145\0\163)
- /Parent 22 0 R
- /Prev 24 0 R
- /Next 26 0 R
+ /Parent 20 0 R
+ /Prev 22 0 R
+ /Next 24 0 R
  /A 13 0 R
 >> endobj
-26 0 obj
+24 0 obj
 <<
  /Title (\376\377\0\64\0\40\0\123\0\145\0\141\0\162\0\143\0\150\0\151\0\156\0\147\0\40\0\106\0\151\0\154\0\145\0\163)
- /Parent 22 0 R
- /Prev 25 0 R
- /Next 27 0 R
+ /Parent 20 0 R
+ /Prev 23 0 R
  /A 15 0 R
 >> endobj
-27 0 obj
-<<
- /Title (\376\377\0\65\0\40\0\124\0\150\0\145\0\40\0\127\0\145\0\142\0\40\0\145\0\170\0\141\0\155\0\160\0\154\0\145\0\56\0\56\0\56)
- /Parent 22 0 R
- /Prev 26 0 R
- /A 17 0 R
->> endobj
-28 0 obj
+25 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F3
 /BaseFont /Helvetica-Bold
 /Encoding /WinAnsiEncoding >>
 endobj
-29 0 obj
+26 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F5
 /BaseFont /Times-Roman
 /Encoding /WinAnsiEncoding >>
 endobj
-30 0 obj
+27 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F1
 /BaseFont /Helvetica
 /Encoding /WinAnsiEncoding >>
 endobj
-31 0 obj
+28 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F9
 /BaseFont /Courier
 /Encoding /WinAnsiEncoding >>
 endobj
-32 0 obj
+29 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F2
 /BaseFont /Helvetica-Oblique
 /Encoding /WinAnsiEncoding >>
 endobj
-33 0 obj
+30 0 obj
 << /Type /Font
 /Subtype /Type1
 /Name /F7
@@ -192,97 +173,88 @@ endobj
 1 0 obj
 << /Type /Pages
 /Count 3
-/Kids [6 0 R 19 0 R 21 0 R ] >>
+/Kids [6 0 R 17 0 R 19 0 R ] >>
 endobj
 2 0 obj
 << /Type /Catalog
 /Pages 1 0 R
- /Outlines 22 0 R
+ /Outlines 20 0 R
  /PageMode /UseOutlines
  >>
 endobj
 3 0 obj
 << 
-/Font << /F3 28 0 R /F5 29 0 R /F1 30 0 R /F9 31 0 R /F2 32 0 R /F7 33 0 R >> 
+/Font << /F3 25 0 R /F5 26 0 R /F1 27 0 R /F9 28 0 R /F2 29 0 R /F7 30 0 R >> 
 /ProcSet [ /PDF /ImageC /Text ] >> 
 endobj
 9 0 obj
 <<
 /S /GoTo
-/D [19 0 R /XYZ 85.0 659.0 null]
+/D [17 0 R /XYZ 85.0 659.0 null]
 >>
 endobj
 11 0 obj
 <<
 /S /GoTo
-/D [19 0 R /XYZ 85.0 580.266 null]
+/D [17 0 R /XYZ 85.0 580.266 null]
 >>
 endobj
 13 0 obj
 <<
 /S /GoTo
-/D [19 0 R /XYZ 85.0 453.932 null]
+/D [17 0 R /XYZ 85.0 453.932 null]
 >>
 endobj
 15 0 obj
 <<
 /S /GoTo
-/D [21 0 R /XYZ 85.0 520.2 null]
+/D [19 0 R /XYZ 85.0 314.2 null]
 >>
 endobj
-17 0 obj
-<<
-/S /GoTo
-/D [21 0 R /XYZ 85.0 316.666 null]
->>
-endobj
-22 0 obj
+20 0 obj
 <<
- /First 23 0 R
- /Last 27 0 R
+ /First 21 0 R
+ /Last 24 0 R
 >> endobj
 xref
-0 34
+0 31
 0000000000 65535 f 
-0000008278 00000 n 
-0000008350 00000 n 
-0000008442 00000 n 
+0000008643 00000 n 
+0000008715 00000 n 
+0000008807 00000 n 
 0000000015 00000 n 
 0000000071 00000 n 
-0000000777 00000 n 
-0000000897 00000 n 
-0000000950 00000 n 
-0000008576 00000 n 
-0000001085 00000 n 
-0000008639 00000 n 
-0000001221 00000 n 
-0000008705 00000 n 
-0000001358 00000 n 
-0000008771 00000 n 
-0000001495 00000 n 
-0000008835 00000 n 
-0000001632 00000 n 
-0000004315 00000 n 
-0000004423 00000 n 
-0000006544 00000 n 
-0000008901 00000 n 
-0000006652 00000 n 
-0000006825 00000 n 
-0000007060 00000 n 
+0000000732 00000 n 
+0000000852 00000 n 
+0000000898 00000 n 
+0000008941 00000 n 
+0000001033 00000 n 
+0000009004 00000 n 
+0000001169 00000 n 
+0000009070 00000 n 
+0000001306 00000 n 
+0000009136 00000 n 
+0000001443 00000 n 
+0000003927 00000 n 
+0000004035 00000 n 
+0000007118 00000 n 
+0000009200 00000 n 
 0000007226 00000 n 
-0000007421 00000 n 
-0000007616 00000 n 
-0000007729 00000 n 
-0000007839 00000 n 
-0000007947 00000 n 
-0000008053 00000 n 
-0000008169 00000 n 
+0000007399 00000 n 
+0000007634 00000 n 
+0000007800 00000 n 
+0000007981 00000 n 
+0000008094 00000 n 
+0000008204 00000 n 
+0000008312 00000 n 
+0000008418 00000 n 
+0000008534 00000 n 
 trailer
 <<
-/Size 34
+/Size 31
 /Root 2 0 R
 /Info 4 0 R
 >>
 startxref
-8952
+9251
 %%EOF

Modified: lucene/dev/branches/realtime_search/lucene/docs/fileformats.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/fileformats.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/fileformats.html (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/fileformats.html Tue Feb 22 01:00:39 2011
@@ -129,11 +129,8 @@ document.write("Last Published: " + docu
 <div class="menuitem">
 <a href="api/core/index.html">Core</a>
 </div>
-<div class="menuitem">
-<a href="api/demo/index.html">Demo</a>
-</div>
-<div onclick="SwitchMenu('menu_1.1.3.4', 'skin/')" id="menu_1.1.3.4Title" class="menutitle">Contrib</div>
-<div id="menu_1.1.3.4" class="menuitemgroup">
+<div onclick="SwitchMenu('menu_1.1.3.3', 'skin/')" id="menu_1.1.3.3Title" class="menutitle">Contrib</div>
+<div id="menu_1.1.3.3" class="menuitemgroup">
 <div class="menuitem">
 <a href="api/contrib-ant/index.html">Ant</a>
 </div>
@@ -147,6 +144,9 @@ document.write("Last Published: " + docu
 <a href="api/contrib-benchmark/index.html">Benchmark</a>
 </div>
 <div class="menuitem">
+<a href="api/contrib-demo/index.html">Demo</a>
+</div>
+<div class="menuitem">
 <a href="api/contrib-highlighter/index.html">Highlighter</a>
 </div>
 <div class="menuitem">

Modified: lucene/dev/branches/realtime_search/lucene/docs/gettingstarted.html
URL: http://svn.apache.org/viewvc/lucene/dev/branches/realtime_search/lucene/docs/gettingstarted.html?rev=1073192&r1=1073191&r2=1073192&view=diff
==============================================================================
--- lucene/dev/branches/realtime_search/lucene/docs/gettingstarted.html (original)
+++ lucene/dev/branches/realtime_search/lucene/docs/gettingstarted.html Tue Feb 22 01:00:39 2011
@@ -129,11 +129,8 @@ document.write("Last Published: " + docu
 <div class="menuitem">
 <a href="api/core/index.html">Core</a>
 </div>
-<div class="menuitem">
-<a href="api/demo/index.html">Demo</a>
-</div>
-<div onclick="SwitchMenu('menu_1.1.3.4', 'skin/')" id="menu_1.1.3.4Title" class="menutitle">Contrib</div>
-<div id="menu_1.1.3.4" class="menuitemgroup">
+<div onclick="SwitchMenu('menu_1.1.3.3', 'skin/')" id="menu_1.1.3.3Title" class="menutitle">Contrib</div>
+<div id="menu_1.1.3.3" class="menuitemgroup">
 <div class="menuitem">
 <a href="api/contrib-ant/index.html">Ant</a>
 </div>
@@ -147,6 +144,9 @@ document.write("Last Published: " + docu
 <a href="api/contrib-benchmark/index.html">Benchmark</a>
 </div>
 <div class="menuitem">
+<a href="api/contrib-demo/index.html">Demo</a>
+</div>
+<div class="menuitem">
 <a href="api/contrib-highlighter/index.html">Highlighter</a>
 </div>
 <div class="menuitem">
@@ -251,7 +251,7 @@ document.write("Last Published: " + docu
 <div class="section">
 <p>
 This document is intended as a "getting started" guide.  It has three audiences: first-time users
-looking to install Apache Lucene in their application or web server; developers looking to modify or base
+looking to install Apache Lucene in their application; developers looking to modify or base
 the applications they develop on Lucene; and developers looking to become involved in and contribute
 to the development of Lucene.  This document is written in tutorial and walk-through format.  The
 goal is to help you "get started".  It does not go into great depth on some of the conceptual or
@@ -275,25 +275,6 @@ may wish to skip sections.
 	command-line Lucene demo.  This section is intended for developers.</li> 
 <p></p>
 
-	
-<li>
-<a href="demo3.html">About installing and configuring the demo template web
-	application</a>.  While this walk-through assumes Tomcat as your container of choice,
-	there is no reason you can't (provided you have the requisite knowledge) adapt the
-	instructions to your container.  This section is intended for those responsible for the
-	development or deployment of Lucene-based web applications.</li> 
-<p></p>
-
-	
-<li>
-<a href="demo4.html">About the sources used to construct the demo template web
-	application</a>.  Please note the template application is designed to highlight features of
-	Lucene and is <b>not</b> an example of best practices.  (One would hopefully use MVC
-	architecture such as provided by Jakarta Struts and taglibs, but showing you how to do that
-	would be WAY beyond the scope of this guide.)  This section is intended for developers and
-	those wishing to customize the demo template web application to their needs.  </li>
-
-
 </ul>
 </div>