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

svn commit: r1658464 - in /lucene/dev/trunk/lucene: join/src/java/org/apache/lucene/search/join/ memory/src/java/org/apache/lucene/index/memory/ misc/src/java/org/apache/lucene/document/ misc/src/java/org/apache/lucene/index/ misc/src/java/org/apache/l...

Author: rmuir
Date: Mon Feb  9 16:51:43 2015
New Revision: 1658464

URL: http://svn.apache.org/r1658464
Log:
LUCENE-6224: cut over more package.htmls

Added:
    lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package.html
    lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package-info.java
      - copied, changed from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package.html
Removed:
    lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package.html
    lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package.html
    lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package.html
Modified:
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/document/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/index/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/search/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/store/package.html
    lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/util/fst/package.html

Copied: lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package-info.java (from r1658398, lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package-info.java?p2=lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package-info.java&p1=lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package.html (original)
+++ lucene/dev/trunk/lucene/join/src/java/org/apache/lucene/search/join/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,96 +1,93 @@
-<!--
- 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.
--->
-<html>
-<body>
-
-<p>This modules support index-time and query-time joins.</p>
-
-<h2>Index-time joins</h2>
-
-<p>The index-time joining support joins while searching, where joined
-  documents are indexed as a single document block using
-  {@link org.apache.lucene.index.IndexWriter#addDocuments IndexWriter.addDocuments()}.  
-  This is useful for any normalized content (XML documents or database tables).  In database terms, all rows for all
-  joined tables matching a single row of the primary table must be
-  indexed as a single document block, with the parent document
-  being last in the group.</p>
-
-<p>When you index in this way, the documents in your index are divided
-  into parent documents (the last document of each block) and child
-  documents (all others).  You provide a {@link org.apache.lucene.search.Filter} that identifies the
-  parent documents, as Lucene does not currently record any information
-  about doc blocks.</p>
-
-<p>At search time, use {@link
-  org.apache.lucene.search.join.ToParentBlockJoinQuery} to remap/join
-  matches from any child {@link org.apache.lucene.search.Query} (ie, a
-  query that matches only child documents) up to the parent document
-  space.  The
-  resulting query can then be used as a clause in any query that
-  matches parent.</p>
-
-<p>If you only care about the parent documents matching the query, you
-  can use any collector to collect the parent hits, but if you'd also
-  like to see which child documents match for each parent document,
-  use the {@link org.apache.lucene.search.join.ToParentBlockJoinCollector} to collect the hits. Once the
-  search is done, you retrieve a {@link
-  org.apache.lucene.search.grouping.TopGroups} instance from the
-  {@link org.apache.lucene.search.join.ToParentBlockJoinCollector#getTopGroups ToParentBlockJoinCollector.getTopGroups()} method.</p>
-
-<p>To map/join in the opposite direction, use {@link
-  org.apache.lucene.search.join.ToChildBlockJoinQuery}.  This wraps
-  any query matching parent documents, creating the joined query
-  matching only child documents.
-
-<h2>Query-time joins</h2>
-
-<p>
-  The query time joining is index term based and implemented as two pass search. The first pass collects all the terms from a fromField
-  that match the fromQuery. The second pass returns all documents that have matching terms in a toField to the terms
-  collected in the first pass.
-</p>
-<p>Query time joining has the following input:</p>
-<ul>
-  <li><code>fromField</code>: The from field to join from.
-  <li><code>fromQuery</code>:  The query executed to collect the from terms. This is usually the user specified query.
-  <li><code>multipleValuesPerDocument</code>:  Whether the fromField contains more than one value per document
-  <li><code>scoreMode</code>:  Defines how scores are translated to the other join side. If you don't care about scoring
-  use {@link org.apache.lucene.search.join.ScoreMode#None} mode. This will disable scoring and is therefore more
-  efficient (requires less memory and is faster).
-  <li><code>toField</code>: The to field to join to
-</ul>
-<p>
-  Basically the query-time joining is accessible from one static method. The user of this method supplies the method
-  with the described input and a <code>IndexSearcher</code> where the from terms need to be collected from. The returned
-  query can be executed with the same <code>IndexSearcher</code>, but also with another <code>IndexSearcher</code>.
-  Example usage of the {@link org.apache.lucene.search.join.JoinUtil#createJoinQuery(String, boolean, String, org.apache.lucene.search.Query, org.apache.lucene.search.IndexSearcher, org.apache.lucene.search.join.ScoreMode)
-  JoinUtil.createJoinQuery()} :
-</p>
-<pre class="prettyprint">
-  String fromField = "from"; // Name of the from field
-  boolean multipleValuesPerDocument = false; // Set only yo true in the case when your fromField has multiple values per document in your index
-  String toField = "to"; // Name of the to field
-  ScoreMode scoreMode = ScoreMode.Max // Defines how the scores are translated into the other side of the join.
-  Query fromQuery = new TermQuery(new Term("content", searchTerm)); // Query executed to collect from values to join to the to values
-
-  Query joinQuery = JoinUtil.createJoinQuery(fromField, multipleValuesPerDocument, toField, fromQuery, fromSearcher, scoreMode);
-  TopDocs topDocs = toSearcher.search(joinQuery, 10); // Note: toSearcher can be the same as the fromSearcher
-  // Render topDocs...
-</pre>
-
-</body>
-</html>
+/*
+ * 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.
+ */
+
+/**
+ * Support for index-time and query-time joins.
+ * <h2>Index-time joins</h2>
+ *
+ * <p>The index-time joining support joins while searching, where joined
+ *   documents are indexed as a single document block using
+ *   {@link org.apache.lucene.index.IndexWriter#addDocuments IndexWriter.addDocuments()}.  
+ *   This is useful for any normalized content (XML documents or database tables).  In database terms, all rows for all
+ *   joined tables matching a single row of the primary table must be
+ *   indexed as a single document block, with the parent document
+ *   being last in the group.</p>
+ * 
+ * <p>When you index in this way, the documents in your index are divided
+ *   into parent documents (the last document of each block) and child
+ *   documents (all others).  You provide a {@link org.apache.lucene.search.Filter} that identifies the
+ *   parent documents, as Lucene does not currently record any information
+ *   about doc blocks.</p>
+ * 
+ * <p>At search time, use {@link
+ *   org.apache.lucene.search.join.ToParentBlockJoinQuery} to remap/join
+ *   matches from any child {@link org.apache.lucene.search.Query} (ie, a
+ *   query that matches only child documents) up to the parent document
+ *   space.  The
+ *   resulting query can then be used as a clause in any query that
+ *   matches parent.</p>
+ * 
+ * <p>If you only care about the parent documents matching the query, you
+ *   can use any collector to collect the parent hits, but if you'd also
+ *   like to see which child documents match for each parent document,
+ *   use the {@link org.apache.lucene.search.join.ToParentBlockJoinCollector} to collect the hits. Once the
+ *   search is done, you retrieve a {@link
+ *   org.apache.lucene.search.grouping.TopGroups} instance from the
+ *   {@link org.apache.lucene.search.join.ToParentBlockJoinCollector#getTopGroups ToParentBlockJoinCollector.getTopGroups()} method.</p>
+ * 
+ * <p>To map/join in the opposite direction, use {@link
+ *   org.apache.lucene.search.join.ToChildBlockJoinQuery}.  This wraps
+ *   any query matching parent documents, creating the joined query
+ *   matching only child documents.
+ * 
+ * <h2>Query-time joins</h2>
+ * 
+ * <p>
+ *   The query time joining is index term based and implemented as two pass search. The first pass collects all the terms from a fromField
+ *   that match the fromQuery. The second pass returns all documents that have matching terms in a toField to the terms
+ *   collected in the first pass.
+ * </p>
+ * <p>Query time joining has the following input:</p>
+ * <ul>
+ *   <li><code>fromField</code>: The from field to join from.
+ *   <li><code>fromQuery</code>:  The query executed to collect the from terms. This is usually the user specified query.
+ *   <li><code>multipleValuesPerDocument</code>:  Whether the fromField contains more than one value per document
+ *   <li><code>scoreMode</code>:  Defines how scores are translated to the other join side. If you don't care about scoring
+ *   use {@link org.apache.lucene.search.join.ScoreMode#None} mode. This will disable scoring and is therefore more
+ *   efficient (requires less memory and is faster).
+ *   <li><code>toField</code>: The to field to join to
+ * </ul>
+ * <p>
+ *   Basically the query-time joining is accessible from one static method. The user of this method supplies the method
+ *   with the described input and a <code>IndexSearcher</code> where the from terms need to be collected from. The returned
+ *   query can be executed with the same <code>IndexSearcher</code>, but also with another <code>IndexSearcher</code>.
+ *   Example usage of the {@link org.apache.lucene.search.join.JoinUtil#createJoinQuery(String, boolean, String, org.apache.lucene.search.Query, org.apache.lucene.search.IndexSearcher, org.apache.lucene.search.join.ScoreMode)
+ *   JoinUtil.createJoinQuery()} :
+ * </p>
+ * <pre class="prettyprint">
+ *   String fromField = "from"; // Name of the from field
+ *   boolean multipleValuesPerDocument = false; // Set only yo true in the case when your fromField has multiple values per document in your index
+ *   String toField = "to"; // Name of the to field
+ *   ScoreMode scoreMode = ScoreMode.Max // Defines how the scores are translated into the other side of the join.
+ *   Query fromQuery = new TermQuery(new Term("content", searchTerm)); // Query executed to collect from values to join to the to values
+ * 
+ *   Query joinQuery = JoinUtil.createJoinQuery(fromField, multipleValuesPerDocument, toField, fromQuery, fromSearcher, scoreMode);
+ *   TopDocs topDocs = toSearcher.search(joinQuery, 10); // Note: toSearcher can be the same as the fromSearcher
+ *   // Render topDocs...
+ * </pre>
+ */
+package org.apache.lucene.search.join;

Copied: lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package-info.java (from r1658398, lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package-info.java?p2=lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package-info.java&p1=lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package.html (original)
+++ lucene/dev/trunk/lucene/memory/src/java/org/apache/lucene/index/memory/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,22 +1,21 @@
-<!doctype html public "-//w3c//dtd html 4.0 transitional//en">
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<HTML>
-<BODY>
-High-performance single-document main memory Apache Lucene fulltext search index.
-</BODY>
-</HTML>
+/**
+ * High-performance single-document main memory Apache Lucene fulltext search index.
+ */
+package org.apache.lucene.index.memory;

Modified: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/document/package.html
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/document/package.html?rev=1658464&r1=1658463&r2=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/document/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/document/package.html Mon Feb  9 16:51:43 2015
@@ -14,6 +14,7 @@
  See the License for the specific language governing permissions and
  limitations under the License.
 -->
+<!-- not a package-info.java, because we already defined this package in core/ -->
 <html>
 <body>
 Misc extensions of the Document/Field API.

Modified: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/index/package.html
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/index/package.html?rev=1658464&r1=1658463&r2=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/index/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/index/package.html Mon Feb  9 16:51:43 2015
@@ -14,6 +14,7 @@
  See the License for the specific language governing permissions and
  limitations under the License.
 -->
+<!-- not a package-info.java, because we already defined this package in core/ -->
 <html>
 <body>
 Misc index tools and index support.

Copied: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package-info.java (from r1658398, lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package-info.java?p2=lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package-info.java&p1=lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/misc/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,22 +1,21 @@
-<!doctype html public "-//w3c//dtd html 4.0 transitional//en">
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html><head></head>
-<body>
-Miscellaneous index tools.
-</body>
-</html>
+/**
+ * Miscellaneous index tools. 
+ */
+package org.apache.lucene.misc;

Modified: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/search/package.html
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/search/package.html?rev=1658464&r1=1658463&r2=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/search/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/search/package.html Mon Feb  9 16:51:43 2015
@@ -14,6 +14,7 @@
  See the License for the specific language governing permissions and
  limitations under the License.
 -->
+<!-- not a package-info.java, because we already defined this package in core/ -->
 <html>
 <body>
 Misc search implementations.

Modified: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/store/package.html
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/store/package.html?rev=1658464&r1=1658463&r2=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/store/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/store/package.html Mon Feb  9 16:51:43 2015
@@ -14,6 +14,7 @@
  See the License for the specific language governing permissions and
  limitations under the License.
 -->
+<!-- not a package-info.java, because we already defined this package in core/ -->
 <html>
 <body>
 Misc Directory implementations.

Copied: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package-info.java (from r1658398, lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package-info.java?p2=lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package-info.java&p1=lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/uninverting/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,21 +1,21 @@
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-Support for creating docvalues on-the-fly from the inverted index at runtime.
-</body>
-</html>
\ No newline at end of file
+/**
+ * Support for creating docvalues on-the-fly from the inverted index at runtime. 
+ */
+package org.apache.lucene.uninverting;

Modified: lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/util/fst/package.html
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/util/fst/package.html?rev=1658464&r1=1658463&r2=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/util/fst/package.html (original)
+++ lucene/dev/trunk/lucene/misc/src/java/org/apache/lucene/util/fst/package.html Mon Feb  9 16:51:43 2015
@@ -14,6 +14,7 @@
  See the License for the specific language governing permissions and
  limitations under the License.
 -->
+<!-- not a package-info.java, because we already defined this package in core/ -->
 <html>
 <body>
 Misc FST classes.

Copied: lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package-info.java (from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package-info.java?p2=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package-info.java&p1=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package.html (original)
+++ lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/docvalues/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,21 +1,21 @@
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-FunctionValues for different data types.
-</body>
-</html>
+/**
+ * FunctionValues for different data types.
+ */
+package org.apache.lucene.queries.function.docvalues;

Copied: lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package-info.java (from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package-info.java?p2=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package-info.java&p1=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package.html (original)
+++ lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,21 +1,21 @@
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-Queries that compute score based upon a function
-</body>
-</html>
+/**
+ * Queries that compute score based upon a function.
+ */
+package org.apache.lucene.queries.function;

Copied: lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package-info.java (from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package-info.java?p2=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package-info.java&p1=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package.html (original)
+++ lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/function/valuesource/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,21 +1,21 @@
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-A variety of functions to use with FunctionQuery.
-</body>
-</html>
+/**
+ * A variety of functions to use with FunctionQuery.
+ */
+package org.apache.lucene.queries.function.valuesource;

Copied: lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package-info.java (from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package-info.java?p2=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package-info.java&p1=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package.html (original)
+++ lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/mlt/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,22 +1,21 @@
-<!doctype html public "-//w3c//dtd html 4.0 transitional//en">
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-Document similarity query generators.
-</body>
-</html>
\ No newline at end of file
+/**
+ * Document similarity query generators.
+ */
+package org.apache.lucene.queries.mlt;

Copied: lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package-info.java (from r1658398, lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package.html)
URL: http://svn.apache.org/viewvc/lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package-info.java?p2=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package-info.java&p1=lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package.html&r1=1658398&r2=1658464&rev=1658464&view=diff
==============================================================================
--- lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package.html (original)
+++ lucene/dev/trunk/lucene/queries/src/java/org/apache/lucene/queries/package-info.java Mon Feb  9 16:51:43 2015
@@ -1,21 +1,21 @@
-<!--
- 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
+/*
+ * 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.
+ */
 
-     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.
--->
-<html>
-<body>
-Filters and Queries that add to core Lucene.
-</body>
-</html>
+/**
+ * Filters and Queries that add to core Lucene.
+ */
+package org.apache.lucene.queries;