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 2012/08/16 18:01:19 UTC

svn commit: r1373896 - in /lucene/dev/branches/branch_4x: ./ lucene/ lucene/core/ lucene/core/src/java/org/apache/lucene/codecs/ lucene/core/src/java/org/apache/lucene/index/ lucene/core/src/java/org/apache/lucene/search/ lucene/core/src/java/org/apach...

Author: rmuir
Date: Thu Aug 16 16:01:19 2012
New Revision: 1373896

URL: http://svn.apache.org/viewvc?rev=1373896&view=rev
Log:
javadocs

Modified:
    lucene/dev/branches/branch_4x/   (props changed)
    lucene/dev/branches/branch_4x/lucene/   (props changed)
    lucene/dev/branches/branch_4x/lucene/core/   (props changed)
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/BlockTermState.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListReader.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListWriter.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/DocTermOrds.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/FieldInfos.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentInfos.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentReadState.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentWriteState.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/IndexSearcher.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/TopDocsCollector.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/ByteBlockPool.java
    lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/fst/FST.java

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/BlockTermState.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/BlockTermState.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/BlockTermState.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/BlockTermState.java Thu Aug 16 16:01:19 2012
@@ -26,11 +26,15 @@ import org.apache.lucene.index.TermState
  * terms dict.
  */
 public class BlockTermState extends OrdTermState {
-  public int docFreq;            // how many docs have this term
-  public long totalTermFreq;     // total number of occurrences of this term
+  /** how many docs have this term */
+  public int docFreq;
+  /** total number of occurrences of this term */
+  public long totalTermFreq;
 
-  public int termBlockOrd;          // the term's ord in the current block
-  public long blockFilePointer;  // fp into the terms dict primary file (_X.tim) that holds this term
+  /** the term's ord in the current block */
+  public int termBlockOrd;
+  /** fp into the terms dict primary file (_X.tim) that holds this term */
+  public long blockFilePointer;
 
   @Override
   public void copyFrom(TermState _other) {

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListReader.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListReader.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListReader.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListReader.java Thu Aug 16 16:01:19 2012
@@ -36,7 +36,7 @@ import org.apache.lucene.util.MathUtil;
  */
 
 public abstract class MultiLevelSkipListReader {
-  // the maximum number of skip levels possible for this index
+  /** the maximum number of skip levels possible for this index */
   protected int maxNumberOfSkipLevels; 
   
   // number of levels in this skip list

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListWriter.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListWriter.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListWriter.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/codecs/MultiLevelSkipListWriter.java Thu Aug 16 16:01:19 2012
@@ -49,7 +49,7 @@ import org.apache.lucene.util.MathUtil;
  */
 
 public abstract class MultiLevelSkipListWriter {
-  // number of levels in this skip list
+  /** number of levels in this skip list */
   protected int numberOfSkipLevels;
   
   // the skip interval in the list with level = 0
@@ -77,8 +77,8 @@ public abstract class MultiLevelSkipList
     }
   }
 
+  /** creates new buffers or empties the existing ones */
   protected void resetSkip() {
-    // creates new buffers or empties the existing ones
     if (skipBuffer == null) {
       init();
     } else {

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/DocTermOrds.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/DocTermOrds.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/DocTermOrds.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/DocTermOrds.java Thu Aug 16 16:01:19 2012
@@ -119,10 +119,13 @@ public class DocTermOrds {
   protected final String field;
 
   protected int numTermsInField;
-  protected long termInstances; // total number of references to term numbers
+  /** total number of references to term numbers */
+  protected long termInstances;
   private long memsz;
-  protected int total_time;  // total time to uninvert the field
-  protected int phase1_time;  // time for phase1 of the uninvert process
+  /** total time to uninvert the field */
+  protected int total_time;
+  /** time for phase1 of the uninvert process */
+  protected int phase1_time;
 
   protected int[] index;
   protected byte[][] tnums = new byte[256][];
@@ -234,7 +237,7 @@ public class DocTermOrds {
   protected void setActualDocFreq(int termNum, int df) throws IOException {
   }
 
-  // Call this only once (if you subclass!)
+  /** Call this only once (if you subclass!) */
   protected void uninvert(final AtomicReader reader, final BytesRef termPrefix) throws IOException {
     //System.out.println("DTO uninvert field=" + field + " prefix=" + termPrefix);
     final long startTime = System.currentTimeMillis();

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/FieldInfos.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/FieldInfos.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/FieldInfos.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/FieldInfos.java Thu Aug 16 16:01:19 2012
@@ -249,11 +249,11 @@ public class FieldInfos implements Itera
       return addOrUpdateInternal(name, -1, isIndexed, storeTermVector, omitNorms, storePayloads, indexOptions, docValues, normType);
     }
 
-    // NOTE: this method does not carry over termVector
-    // booleans nor docValuesType; the indexer chain
-    // (TermVectorsConsumerPerField, DocFieldProcessor) must
-    // set these fields when they succeed in consuming
-    // the document:
+    /** NOTE: this method does not carry over termVector
+     *  booleans nor docValuesType; the indexer chain
+     *  (TermVectorsConsumerPerField, DocFieldProcessor) must
+     *  set these fields when they succeed in consuming
+     *  the document */
     public FieldInfo addOrUpdate(String name, IndexableFieldType fieldType) {
       // TODO: really, indexer shouldn't even call this
       // method (it's only called from DocFieldProcessor);

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentInfos.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentInfos.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentInfos.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentInfos.java Thu Aug 16 16:01:19 2012
@@ -137,7 +137,8 @@ public final class SegmentInfos implemen
                                // or wrote; this is normally the same as generation except if
                                // there was an IOException that had interrupted a commit
 
-  public Map<String,String> userData = Collections.<String,String>emptyMap();       // Opaque Map<String, String> that user can specify during IndexWriter.commit
+  /** Opaque Map&lt;String, String&gt; that user can specify during IndexWriter.commit */
+  public Map<String,String> userData = Collections.<String,String>emptyMap();
   
   private List<SegmentInfoPerCommit> segments = new ArrayList<SegmentInfoPerCommit>();
   

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentReadState.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentReadState.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentReadState.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentReadState.java Thu Aug 16 16:01:19 2012
@@ -30,11 +30,11 @@ public class SegmentReadState {
   public final FieldInfos fieldInfos;
   public final IOContext context;
 
-  // NOTE: if this is < 0, that means "defer terms index
-  // load until needed".  But if the codec must load the
-  // terms index on init (preflex is the only once currently
-  // that must do so), then it should negate this value to
-  // get the app's terms divisor:
+  /** NOTE: if this is &lt; 0, that means "defer terms index
+   *  load until needed".  But if the codec must load the
+   *  terms index on init (preflex is the only once currently
+   *  that must do so), then it should negate this value to
+   *  get the app's terms divisor */
   public int termsIndexDivisor;
   public final String segmentSuffix;
 

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentWriteState.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentWriteState.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentWriteState.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/index/SegmentWriteState.java Thu Aug 16 16:01:19 2012
@@ -33,11 +33,11 @@ public class SegmentWriteState {
   public final FieldInfos fieldInfos;
   public int delCountOnFlush;
 
-  // Deletes to apply while we are flushing the segment.  A
-  // Term is enrolled in here if it was deleted at one
-  // point, and it's mapped to the docIDUpto, meaning any
-  // docID < docIDUpto containing this term should be
-  // deleted.
+  /** Deletes to apply while we are flushing the segment.  A
+   *  Term is enrolled in here if it was deleted at one
+   *  point, and it's mapped to the docIDUpto, meaning any
+   *  docID &lt; docIDUpto containing this term should be
+   *  deleted. */
   public final BufferedDeletes segDeletes;
 
   // Lazily created:

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/IndexSearcher.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/IndexSearcher.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/IndexSearcher.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/IndexSearcher.java Thu Aug 16 16:01:19 2012
@@ -82,7 +82,7 @@ public class IndexSearcher {
   // in the next release
   protected final IndexReaderContext readerContext;
   protected final List<AtomicReaderContext> leafContexts;
-  // used with executor - each slice holds a set of leafs executed within one thread
+  /** used with executor - each slice holds a set of leafs executed within one thread */
   protected final LeafSlice[] leafSlices;
 
   // These are only used for multi-threaded search

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/TopDocsCollector.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/TopDocsCollector.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/TopDocsCollector.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/search/TopDocsCollector.java Thu Aug 16 16:01:19 2012
@@ -33,8 +33,8 @@ import org.apache.lucene.util.PriorityQu
  */
 public abstract class TopDocsCollector<T extends ScoreDoc> extends Collector {
 
-  // This is used in case topDocs() is called with illegal parameters, or there
-  // simply aren't (enough) results.
+  /** This is used in case topDocs() is called with illegal parameters, or there
+   *  simply aren't (enough) results. */
   protected static final TopDocs EMPTY_TOPDOCS = new TopDocs(0, new ScoreDoc[0], Float.NaN);
   
   /**

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/ByteBlockPool.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/ByteBlockPool.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/ByteBlockPool.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/ByteBlockPool.java Thu Aug 16 16:01:19 2012
@@ -117,10 +117,13 @@ public final class ByteBlockPool {
   public byte[][] buffers = new byte[10][];
 
   int bufferUpto = -1;                        // Which buffer we are upto
-  public int byteUpto = BYTE_BLOCK_SIZE;             // Where we are in head buffer
+  /** Where we are in head buffer */
+  public int byteUpto = BYTE_BLOCK_SIZE;
 
-  public byte[] buffer;                              // Current head buffer
-  public int byteOffset = -BYTE_BLOCK_SIZE;          // Current head offset
+  /** Current head buffer */
+  public byte[] buffer;
+  /** Current head offset */
+  public int byteOffset = -BYTE_BLOCK_SIZE;
 
   private final Allocator allocator;
 

Modified: lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/fst/FST.java
URL: http://svn.apache.org/viewvc/lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/fst/FST.java?rev=1373896&r1=1373895&r2=1373896&view=diff
==============================================================================
--- lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/fst/FST.java (original)
+++ lucene/dev/branches/branch_4x/lucene/core/src/java/org/apache/lucene/util/fst/FST.java Thu Aug 16 16:01:19 2012
@@ -158,7 +158,7 @@ public final class FST<T> {
   private final boolean packed;
   private PackedInts.Reader nodeRefToAddress;
 
-  // If arc has this label then that arc is final/accepted
+  /** If arc has this label then that arc is final/accepted */
   public static final int END_LABEL = -1;
 
   private boolean allowArrayArcs = true;
@@ -174,7 +174,7 @@ public final class FST<T> {
     // building an FST w/ willPackFST=true:
     int node;
 
-    // To node (ord or address):
+    /** To node (ord or address) */
     public int target;
 
     byte flags;
@@ -542,8 +542,8 @@ public final class FST<T> {
     return v;
   }
 
-  // returns true if the node at this address has any
-  // outgoing arcs
+  /** returns true if the node at this address has any
+   *  outgoing arcs */
   public static<T> boolean targetHasArcs(Arc<T> arc) {
     return arc.target > 0;
   }