You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucenenet.apache.org by ni...@apache.org on 2017/06/01 22:49:01 UTC

[5/9] lucenenet git commit: SWEEP: Lucene.Net.Index: Fixed up documentation comments for types starting with M-Z

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SegmentReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SegmentReader.cs b/src/Lucene.Net/Index/SegmentReader.cs
index a795209..c5baf10 100644
--- a/src/Lucene.Net/Index/SegmentReader.cs
+++ b/src/Lucene.Net/Index/SegmentReader.cs
@@ -36,10 +36,11 @@ namespace Lucene.Net.Index
     using TermVectorsReader = Lucene.Net.Codecs.TermVectorsReader;
 
     /// <summary>
-    /// IndexReader implementation over a single segment.
-    /// <p>
+    /// <see cref="IndexReader"/> implementation over a single segment.
+    /// <para/>
     /// Instances pointing to the same segment (but with different deletes, etc)
     /// may share the same core data.
+    /// <para/>
     /// @lucene.experimental
     /// </summary>
 #if FEATURE_SERIALIZABLE
@@ -94,9 +95,9 @@ namespace Lucene.Net.Index
         private readonly IList<long?> dvGens = new List<long?>();
 
         /// <summary>
-        /// Constructs a new SegmentReader with a new core. </summary>
+        /// Constructs a new <see cref="SegmentReader"/> with a new core. </summary>
         /// <exception cref="CorruptIndexException"> if the index is corrupt </exception>
-        /// <exception cref="IOException"> if there is a low-level IO error </exception>
+        /// <exception cref="System.IO.IOException"> if there is a low-level IO error </exception>
         // TODO: why is this public?
         public SegmentReader(SegmentCommitInfo si, int termInfosIndexDivisor, IOContext context)
         {
@@ -149,9 +150,9 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Create new SegmentReader sharing core from a previous
-        ///  SegmentReader and loading new live docs from a new
-        ///  deletes file.  Used by openIfChanged.
+        /// Create new <see cref="SegmentReader"/> sharing core from a previous
+        /// <see cref="SegmentReader"/> and loading new live docs from a new
+        /// deletes file. Used by <see cref="DirectoryReader.OpenIfChanged(DirectoryReader)"/>.
         /// </summary>
         internal SegmentReader(SegmentCommitInfo si, SegmentReader sr)
             : this(si, sr, si.Info.Codec.LiveDocsFormat.ReadLiveDocs(si.Info.Dir, si, IOContext.READ_ONCE), si.Info.DocCount - si.DelCount)
@@ -159,10 +160,10 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Create new SegmentReader sharing core from a previous
-        ///  SegmentReader and using the provided in-memory
-        ///  liveDocs.  Used by IndexWriter to provide a new NRT
-        ///  reader
+        /// Create new <see cref="SegmentReader"/> sharing core from a previous
+        /// <see cref="SegmentReader"/> and using the provided in-memory
+        /// liveDocs.  Used by <see cref="IndexWriter"/> to provide a new NRT
+        /// reader
         /// </summary>
         internal SegmentReader(SegmentCommitInfo si, SegmentReader sr, IBits liveDocs, int numDocs)
         {
@@ -231,8 +232,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Reads the most recent <seealso cref="FieldInfos"/> of the given segment info.
-        ///
+        /// Reads the most recent <see cref="Index.FieldInfos"/> of the given segment info.
+        /// <para/>
         /// @lucene.internal
         /// </summary>
         internal static FieldInfos ReadFieldInfos(SegmentCommitInfo info)
@@ -329,9 +330,10 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Expert: retrieve thread-private {@link
-        ///  StoredFieldsReader}
-        ///  @lucene.internal
+        /// Expert: retrieve thread-private 
+        /// <see cref="StoredFieldsReader"/>
+        /// <para/>
+        /// @lucene.internal
         /// </summary>
         public StoredFieldsReader FieldsReader
         {
@@ -376,9 +378,10 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Expert: retrieve thread-private {@link
-        ///  TermVectorsReader}
-        ///  @lucene.internal
+        /// Expert: retrieve thread-private
+        /// <see cref="Codecs.TermVectorsReader"/>
+        /// <para/>
+        /// @lucene.internal
         /// </summary>
         public TermVectorsReader TermVectorsReader
         {
@@ -427,7 +430,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Return the SegmentInfoPerCommit of the segment this reader is reading.
+        /// Return the <see cref="SegmentCommitInfo"/> of the segment this reader is reading.
         /// </summary>
         public SegmentCommitInfo SegmentInfo
         {
@@ -474,7 +477,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Returns term infos index divisor originally passed to
-        ///  <seealso cref="#SegmentReader(SegmentCommitInfo, int, IOContext)"/>.
+        /// <see cref="SegmentReader(SegmentCommitInfo, int, IOContext)"/>.
         /// </summary>
         public int TermInfosIndexDivisor
         {
@@ -661,29 +664,29 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Called when the shared core for this SegmentReader
-        /// is closed.
-        /// <p>
-        /// this listener is called only once all SegmentReaders
-        /// sharing the same core are closed.  At this point it
+        /// Called when the shared core for this <see cref="SegmentReader"/>
+        /// is disposed.
+        /// <para>
+        /// This listener is called only once all <see cref="SegmentReader"/>s
+        /// sharing the same core are disposed.  At this point it
         /// is safe for apps to evict this reader from any caches
-        /// keyed on <seealso cref="#getCoreCacheKey"/>.  this is the same
-        /// interface that <seealso cref="IFieldCache"/> uses, internally,
-        /// to evict entries.</p>
+        /// keyed on <see cref="CoreCacheKey"/>.  This is the same
+        /// interface that <see cref="Search.IFieldCache"/> uses, internally,
+        /// to evict entries.</para>
         ///
         /// @lucene.experimental
         /// </summary>
-        public interface ICoreClosedListener
+        public interface ICoreClosedListener // LUCENENET TODO: API Rename ICoreDisposedListener
         {
             /// <summary>
-            /// Invoked when the shared core of the original {@code
-            ///  SegmentReader} has closed.
+            /// Invoked when the shared core of the original 
+            /// <see cref="SegmentReader"/> has disposed.
             /// </summary>
-            void OnClose(object ownerCoreCacheKey);
+            void OnClose(object ownerCoreCacheKey); // LUCENENET TODO: API Rename OnDispose()
         }
 
         /// <summary>
-        /// Expert: adds a CoreClosedListener to this reader's shared core </summary>
+        /// Expert: adds a <see cref="ICoreClosedListener"/> to this reader's shared core </summary>
         public void AddCoreClosedListener(ICoreClosedListener listener)
         {
             EnsureOpen();
@@ -691,7 +694,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Expert: removes a CoreClosedListener from this reader's shared core </summary>
+        /// Expert: removes a <see cref="ICoreClosedListener"/> from this reader's shared core </summary>
         public void RemoveCoreClosedListener(ICoreClosedListener listener)
         {
             EnsureOpen();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SegmentWriteState.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SegmentWriteState.cs b/src/Lucene.Net/Index/SegmentWriteState.cs
index 5a8ae5b..0d2f091 100644
--- a/src/Lucene.Net/Index/SegmentWriteState.cs
+++ b/src/Lucene.Net/Index/SegmentWriteState.cs
@@ -28,6 +28,7 @@ namespace Lucene.Net.Index
 
     /// <summary>
     /// Holder class for common parameters used during write.
+    /// <para/>
     /// @lucene.experimental
     /// </summary>
 #if FEATURE_SERIALIZABLE
@@ -36,33 +37,33 @@ namespace Lucene.Net.Index
     public class SegmentWriteState
     {
         /// <summary>
-        /// <seealso cref="InfoStream"/> used for debugging messages. </summary>
+        /// <see cref="Util.InfoStream"/> used for debugging messages. </summary>
         public InfoStream InfoStream { get; private set; }
 
         /// <summary>
-        /// <seealso cref="Directory"/> where this segment will be written
-        ///  to.
+        /// <see cref="Store.Directory"/> where this segment will be written
+        /// to.
         /// </summary>
         public Directory Directory { get; private set; }
 
         /// <summary>
-        /// <seealso cref="SegmentInfo"/> describing this segment. </summary>
+        /// <see cref="Index.SegmentInfo"/> describing this segment. </summary>
         public SegmentInfo SegmentInfo { get; private set; }
 
         /// <summary>
-        /// <seealso cref="FieldInfos"/> describing all fields in this
-        ///  segment.
+        /// <see cref="Index.FieldInfos"/> describing all fields in this
+        /// segment.
         /// </summary>
         public FieldInfos FieldInfos { get; private set; }
 
         /// <summary>
         /// Number of deleted documents set while flushing the
-        ///  segment.
+        /// segment.
         /// </summary>
         public int DelCountOnFlush { get; set; }
 
         /// <summary>
-        /// Deletes and updates to apply while we are flushing the segment. A Term is
+        /// Deletes and updates to apply while we are flushing the segment. A <see cref="Term"/> is
         /// enrolled in here if it was deleted/updated at one point, and it's mapped to
         /// the docIDUpto, meaning any docID &lt; docIDUpto containing this term should
         /// be deleted/updated.
@@ -70,18 +71,18 @@ namespace Lucene.Net.Index
         public BufferedUpdates SegUpdates { get; private set; }
 
         /// <summary>
-        /// <seealso cref="IMutableBits"/> recording live documents; this is
-        ///  only set if there is one or more deleted documents.
+        /// <see cref="IMutableBits"/> recording live documents; this is
+        /// only set if there is one or more deleted documents.
         /// </summary>
         public IMutableBits LiveDocs { get; set; }
 
         /// <summary>
         /// Unique suffix for any postings files written for this
-        ///  segment.  <seealso cref="PerFieldPostingsFormat"/> sets this for
-        ///  each of the postings formats it wraps.  If you create
-        ///  a new <seealso cref="PostingsFormat"/> then any files you
-        ///  write/read must be derived using this suffix (use
-        ///  <seealso cref="IndexFileNames#segmentFileName(String,String,String)"/>).
+        /// segment.  <see cref="PerFieldPostingsFormat"/> sets this for
+        /// each of the postings formats it wraps.  If you create
+        /// a new <see cref="PostingsFormat"/> then any files you
+        /// write/read must be derived using this suffix (use
+        /// <see cref="IndexFileNames.SegmentFileName(string,string,string)"/>).
         /// </summary>
         public string SegmentSuffix { get; private set; }
 
@@ -95,8 +96,8 @@ namespace Lucene.Net.Index
         public int TermIndexInterval { get; set; } // TODO: this should be private to the codec, not settable here or in IWC
 
         /// <summary>
-        /// <seealso cref="IOContext"/> for all writes; you should pass this
-        ///  to <seealso cref="Directory#createOutput(String,IOContext)"/>.
+        /// <see cref="IOContext"/> for all writes; you should pass this
+        /// to <see cref="Directory.CreateOutput(string, IOContext)"/>.
         /// </summary>
         public IOContext Context { get; private set; }
 
@@ -110,8 +111,8 @@ namespace Lucene.Net.Index
         /// <summary>
         /// Constructor which takes segment suffix.
         /// </summary>
-        /// <seealso cref= #SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, int,
-        ///      BufferedUpdates, IOContext) </seealso>
+        /// <seealso cref="SegmentWriteState(InfoStream, Directory, SegmentInfo, FieldInfos, int,
+        ///      BufferedUpdates, IOContext)"/>
         public SegmentWriteState(InfoStream infoStream, Directory directory, SegmentInfo segmentInfo, FieldInfos fieldInfos, int termIndexInterval, BufferedUpdates segUpdates, IOContext context, string segmentSuffix)
         {
             this.InfoStream = infoStream;
@@ -125,7 +126,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Create a shallow copy of <seealso cref="SegmentWriteState"/> with a new segment suffix. </summary>
+        /// Create a shallow copy of <see cref="SegmentWriteState"/> with a new segment suffix. </summary>
         public SegmentWriteState(SegmentWriteState state, string segmentSuffix)
         {
             InfoStream = state.InfoStream;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SerialMergeScheduler.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SerialMergeScheduler.cs b/src/Lucene.Net/Index/SerialMergeScheduler.cs
index c150594..14dea0e 100644
--- a/src/Lucene.Net/Index/SerialMergeScheduler.cs
+++ b/src/Lucene.Net/Index/SerialMergeScheduler.cs
@@ -20,8 +20,8 @@ namespace Lucene.Net.Index
      */
 
     /// <summary>
-    /// A <seealso cref="MergeScheduler"/> that simply does each merge
-    ///  sequentially, using the current thread.
+    /// A <see cref="MergeScheduler"/> that simply does each merge
+    /// sequentially, using the current thread.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SimpleMergedSegmentWarmer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SimpleMergedSegmentWarmer.cs b/src/Lucene.Net/Index/SimpleMergedSegmentWarmer.cs
index 1090df8..26989ce 100644
--- a/src/Lucene.Net/Index/SimpleMergedSegmentWarmer.cs
+++ b/src/Lucene.Net/Index/SimpleMergedSegmentWarmer.cs
@@ -35,8 +35,8 @@ namespace Lucene.Net.Index
         private readonly InfoStream infoStream;
 
         /// <summary>
-        /// Creates a new SimpleMergedSegmentWarmer </summary>
-        /// <param name="infoStream"> InfoStream to log statistics about warming. </param>
+        /// Creates a new <see cref="SimpleMergedSegmentWarmer"/> </summary>
+        /// <param name="infoStream"> <see cref="InfoStream"/> to log statistics about warming. </param>
         public SimpleMergedSegmentWarmer(InfoStream infoStream)
         {
             this.infoStream = infoStream;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SingleTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SingleTermsEnum.cs b/src/Lucene.Net/Index/SingleTermsEnum.cs
index 7f35e75..bb89193 100644
--- a/src/Lucene.Net/Index/SingleTermsEnum.cs
+++ b/src/Lucene.Net/Index/SingleTermsEnum.cs
@@ -23,11 +23,11 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// Subclass of FilteredTermsEnum for enumerating a single term.
+    /// Subclass of <see cref="FilteredTermsEnum"/> for enumerating a single term.
     /// <para/>
     /// For example, this can be used by <see cref="Search.MultiTermQuery"/>s
     /// that need only visit one term, but want to preserve
-    /// MultiTermQuery semantics such as <see cref="Search.MultiTermQuery.MultiTermRewriteMethod"/>.
+    /// <see cref="Search.MultiTermQuery"/> semantics such as <see cref="Search.MultiTermQuery.MultiTermRewriteMethod"/>.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -37,8 +37,8 @@ namespace Lucene.Net.Index
         private readonly BytesRef singleRef;
 
         /// <summary>
-        /// Creates a new <code>SingleTermsEnum</code>.
-        /// <p>
+        /// Creates a new <see cref="SingleTermsEnum"/>.
+        /// <para/>
         /// After calling the constructor the enumeration is already pointing to the term,
         /// if it exists.
         /// </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SingletonSortedSetDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SingletonSortedSetDocValues.cs b/src/Lucene.Net/Index/SingletonSortedSetDocValues.cs
index cb829fb..22cc8c4 100644
--- a/src/Lucene.Net/Index/SingletonSortedSetDocValues.cs
+++ b/src/Lucene.Net/Index/SingletonSortedSetDocValues.cs
@@ -24,9 +24,9 @@ namespace Lucene.Net.Index
 
     /// <summary>
     /// Exposes multi-valued view over a single-valued instance.
-    /// <p>
-    /// this can be used if you want to have one multi-valued implementation
-    /// against e.g. FieldCache.getDocTermOrds that also works for single-valued
+    /// <para/>
+    /// This can be used if you want to have one multi-valued implementation
+    /// against e.g. <see cref="Search.IFieldCache.GetDocTermOrds(AtomicReader, string)"/> that also works for single-valued
     /// fields.
     /// </summary>
 #if FEATURE_SERIALIZABLE
@@ -39,7 +39,7 @@ namespace Lucene.Net.Index
         private bool set;
 
         /// <summary>
-        /// Creates a multi-valued view over the provided SortedDocValues </summary>
+        /// Creates a multi-valued view over the provided <see cref="Index.SortedDocValues"/> </summary>
         public SingletonSortedSetDocValues(SortedDocValues @in)
         {
             this.@in = @in;
@@ -47,7 +47,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Return the wrapped <seealso cref="SortedDocValues"/> </summary>
+        /// Return the wrapped <see cref="Index.SortedDocValues"/> </summary>
         public SortedDocValues SortedDocValues
         {
             get

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SlowCompositeReaderWrapper.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SlowCompositeReaderWrapper.cs b/src/Lucene.Net/Index/SlowCompositeReaderWrapper.cs
index 8d80e63..7be60e5 100644
--- a/src/Lucene.Net/Index/SlowCompositeReaderWrapper.cs
+++ b/src/Lucene.Net/Index/SlowCompositeReaderWrapper.cs
@@ -27,17 +27,17 @@ namespace Lucene.Net.Index
     using OrdinalMap = Lucene.Net.Index.MultiDocValues.OrdinalMap;
 
     /// <summary>
-    /// this class forces a composite reader (eg a {@link
-    /// MultiReader} or <seealso cref="DirectoryReader"/>) to emulate an
-    /// atomic reader.  this requires implementing the postings
-    /// APIs on-the-fly, using the static methods in {@link
-    /// MultiFields}, <seealso cref="MultiDocValues"/>, by stepping through
+    /// This class forces a composite reader (eg a 
+    /// <see cref="MultiReader"/> or <see cref="DirectoryReader"/>) to emulate an
+    /// atomic reader.  This requires implementing the postings
+    /// APIs on-the-fly, using the static methods in 
+    /// <see cref="MultiFields"/>, <see cref="MultiDocValues"/>, by stepping through
     /// the sub-readers to merge fields/terms, appending docs, etc.
     ///
-    /// <p><b>NOTE</b>: this class almost always results in a
+    /// <para/><b>NOTE</b>: This class almost always results in a
     /// performance hit.  If this is important to your use case,
     /// you'll get better performance by gathering the sub readers using
-    /// <seealso cref="IndexReader#getContext()"/> to get the
+    /// <see cref="IndexReader.Context"/> to get the
     /// atomic leaves and then operate per-AtomicReader,
     /// instead of using this class.
     /// </summary>
@@ -51,8 +51,8 @@ namespace Lucene.Net.Index
         private readonly IBits liveDocs;
 
         /// <summary>
-        /// this method is sugar for getting an <seealso cref="AtomicReader"/> from
-        /// an <seealso cref="IndexReader"/> of any kind. If the reader is already atomic,
+        /// This method is sugar for getting an <see cref="AtomicReader"/> from
+        /// an <see cref="IndexReader"/> of any kind. If the reader is already atomic,
         /// it is returned unchanged, otherwise wrapped by this class.
         /// </summary>
         public static AtomicReader Wrap(IndexReader reader)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SnapshotDeletionPolicy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SnapshotDeletionPolicy.cs b/src/Lucene.Net/Index/SnapshotDeletionPolicy.cs
index 0cd7e80..8015092 100644
--- a/src/Lucene.Net/Index/SnapshotDeletionPolicy.cs
+++ b/src/Lucene.Net/Index/SnapshotDeletionPolicy.cs
@@ -24,20 +24,20 @@ namespace Lucene.Net.Index
     using Directory = Lucene.Net.Store.Directory;
 
     /// <summary>
-    /// An <seealso cref="IndexDeletionPolicy"/> that wraps any other
-    /// <seealso cref="IndexDeletionPolicy"/> and adds the ability to hold and later release
-    /// snapshots of an index. While a snapshot is held, the <seealso cref="IndexWriter"/> will
+    /// An <see cref="IndexDeletionPolicy"/> that wraps any other
+    /// <see cref="IndexDeletionPolicy"/> and adds the ability to hold and later release
+    /// snapshots of an index. While a snapshot is held, the <see cref="IndexWriter"/> will
     /// not remove any files associated with it even if the index is otherwise being
     /// actively, arbitrarily changed. Because we wrap another arbitrary
-    /// <seealso cref="IndexDeletionPolicy"/>, this gives you the freedom to continue using
-    /// whatever <seealso cref="IndexDeletionPolicy"/> you would normally want to use with your
+    /// <see cref="IndexDeletionPolicy"/>, this gives you the freedom to continue using
+    /// whatever <see cref="IndexDeletionPolicy"/> you would normally want to use with your
     /// index.
     ///
-    /// <p>
-    /// this class maintains all snapshots in-memory, and so the information is not
+    /// <para/>
+    /// This class maintains all snapshots in-memory, and so the information is not
     /// persisted and not protected against system failures. If persistence is
-    /// important, you can use <seealso cref="PersistentSnapshotDeletionPolicy"/>.
-    ///
+    /// important, you can use <see cref="PersistentSnapshotDeletionPolicy"/>.
+    /// <para/>
     /// @lucene.experimental
     /// </summary>
 #if FEATURE_SERIALIZABLE
@@ -47,20 +47,20 @@ namespace Lucene.Net.Index
     {
         /// <summary>
         /// Records how many snapshots are held against each
-        ///  commit generation
+        /// commit generation
         /// </summary>
         protected IDictionary<long, int> m_refCounts = new Dictionary<long, int>();
 
         /// <summary>
-        /// Used to map gen to IndexCommit. </summary>
+        /// Used to map gen to <see cref="IndexCommit"/>. </summary>
         protected IDictionary<long?, IndexCommit> m_indexCommits = new Dictionary<long?, IndexCommit>();
 
         /// <summary>
-        /// Wrapped <seealso cref="IndexDeletionPolicy"/> </summary>
+        /// Wrapped <see cref="IndexDeletionPolicy"/> </summary>
         private IndexDeletionPolicy primary;
 
         /// <summary>
-        /// Most recently committed <seealso cref="IndexCommit"/>. </summary>
+        /// Most recently committed <see cref="IndexCommit"/>. </summary>
         protected IndexCommit m_lastCommit;
 
         /// <summary>
@@ -68,8 +68,8 @@ namespace Lucene.Net.Index
         private bool initCalled;
 
         /// <summary>
-        /// Sole constructor, taking the incoming {@link
-        ///  IndexDeletionPolicy} to wrap.
+        /// Sole constructor, taking the incoming 
+        /// <see cref="IndexDeletionPolicy"/> to wrap.
         /// </summary>
         public SnapshotDeletionPolicy(IndexDeletionPolicy primary)
         {
@@ -109,7 +109,7 @@ namespace Lucene.Net.Index
         /// Release a snapshotted commit.
         /// </summary>
         /// <param name="commit">
-        ///          the commit previously returned by <seealso cref="#snapshot"/> </param>
+        ///          the commit previously returned by <see cref="Snapshot()"/> </param>
         public virtual void Release(IndexCommit commit)
         {
             lock (this)
@@ -147,7 +147,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Increments the refCount for this <seealso cref="IndexCommit"/>. </summary>
+        /// Increments the refCount for this <see cref="IndexCommit"/>. </summary>
         protected internal virtual void IncRef(IndexCommit ic)
         {
             lock (this)
@@ -170,20 +170,20 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Snapshots the last commit and returns it. Once a commit is 'snapshotted,' it is protected
-        /// from deletion (as long as this <seealso cref="IndexDeletionPolicy"/> is used). The
-        /// snapshot can be removed by calling <seealso cref="#release(IndexCommit)"/> followed
-        /// by a call to <seealso cref="IndexWriter#deleteUnusedFiles()"/>.
+        /// from deletion (as long as this <see cref="IndexDeletionPolicy"/> is used). The
+        /// snapshot can be removed by calling <see cref="Release(IndexCommit)"/> followed
+        /// by a call to <see cref="IndexWriter.DeleteUnusedFiles()"/>.
         ///
-        /// <p>
+        /// <para/>
         /// <b>NOTE:</b> while the snapshot is held, the files it references will not
         /// be deleted, which will consume additional disk space in your index. If you
         /// take a snapshot at a particularly bad time (say just before you call
-        /// forceMerge) then in the worst case this could consume an extra 1X of your
+        /// <see cref="IndexWriter.ForceMerge(int)"/>) then in the worst case this could consume an extra 1X of your
         /// total index size, until you release the snapshot.
         /// </summary>
-        /// <exception cref="IllegalStateException">
+        /// <exception cref="InvalidOperationException">
         ///           if this index does not have any commits yet </exception>
-        /// <returns> the <seealso cref="IndexCommit"/> that was snapshotted. </returns>
+        /// <returns> the <see cref="IndexCommit"/> that was snapshotted. </returns>
         public virtual IndexCommit Snapshot()
         {
             lock (this)
@@ -205,7 +205,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns all IndexCommits held by at least one snapshot. </summary>
+        /// Returns all <see cref="IndexCommit"/>s held by at least one snapshot. </summary>
         public virtual IList<IndexCommit> GetSnapshots()
         {
             lock (this)
@@ -234,9 +234,9 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Retrieve an <seealso cref="IndexCommit"/> from its generation;
-        ///  returns null if this IndexCommit is not currently
-        ///  snapshotted
+        /// Retrieve an <see cref="IndexCommit"/> from its generation;
+        /// returns <c>null</c> if this <see cref="IndexCommit"/> is not currently
+        /// snapshotted
         /// </summary>
         public virtual IndexCommit GetIndexCommit(long gen)
         {
@@ -260,8 +260,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Wraps each <seealso cref="IndexCommit"/> as a {@link
-        ///  SnapshotCommitPoint}.
+        /// Wraps each <see cref="IndexCommit"/> as a 
+        /// <see cref="SnapshotCommitPoint"/>.
         /// </summary>
         private IList<IndexCommit> WrapCommits<T>(IList<T> commits)
             where T : IndexCommit
@@ -275,20 +275,20 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Wraps a provided <seealso cref="IndexCommit"/> and prevents it
-        ///  from being deleted.
+        /// Wraps a provided <see cref="IndexCommit"/> and prevents it
+        /// from being deleted.
         /// </summary>
         private class SnapshotCommitPoint : IndexCommit
         {
             private readonly SnapshotDeletionPolicy outerInstance;
 
             /// <summary>
-            /// The <seealso cref="IndexCommit"/> we are preventing from deletion. </summary>
+            /// The <see cref="IndexCommit"/> we are preventing from deletion. </summary>
             protected IndexCommit m_cp;
 
             /// <summary>
-            /// Creates a {@code SnapshotCommitPoint} wrapping the provided
-            ///  <seealso cref="IndexCommit"/>.
+            /// Creates a <see cref="SnapshotCommitPoint"/> wrapping the provided
+            /// <see cref="IndexCommit"/>.
             /// </summary>
             protected internal SnapshotCommitPoint(SnapshotDeletionPolicy outerInstance, IndexCommit cp)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedDocValues.cs b/src/Lucene.Net/Index/SortedDocValues.cs
index 0ed7556..99417d8 100644
--- a/src/Lucene.Net/Index/SortedDocValues.cs
+++ b/src/Lucene.Net/Index/SortedDocValues.cs
@@ -22,9 +22,9 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// A per-document byte[] with presorted values.
-    /// <p>
-    /// Per-Document values in a SortedDocValues are deduplicated, dereferenced,
+    /// A per-document <see cref="T:byte[]"/> with presorted values.
+    /// <para/>
+    /// Per-Document values in a <see cref="SortedDocValues"/> are deduplicated, dereferenced,
     /// and sorted into a dictionary of unique values. A pointer to the
     /// dictionary value (ordinal) can be retrieved for each document. Ordinals
     /// are dense and in increasing sorted order.
@@ -52,14 +52,14 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Retrieves the value for the specified ordinal. </summary>
-        /// <param name="ord"> ordinal to lookup (must be &gt;= 0 and &lt <seealso cref="#getValueCount()"/>) </param>
+        /// <param name="ord"> ordinal to lookup (must be &gt;= 0 and &lt; <see cref="ValueCount"/>) </param>
         /// <param name="result"> will be populated with the ordinal's value </param>
-        /// <seealso cref= #getOrd(int)  </seealso>
+        /// <seealso cref="GetOrd(int)"/>
         public abstract void LookupOrd(int ord, BytesRef result);
 
         /// <summary>
         /// Returns the number of unique values. </summary>
-        /// <returns> number of unique values in this SortedDocValues. this is
+        /// <returns> Number of unique values in this <see cref="SortedDocValues"/>. This is
         ///         also equivalent to one plus the maximum ordinal. </returns>
         public abstract int ValueCount { get; }
 
@@ -79,12 +79,11 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// If {@code key} exists, returns its ordinal, else
-        ///  returns {@code -insertionPoint-1}, like {@code
-        ///  Arrays.binarySearch}.
+        /// If <paramref name="key"/> exists, returns its ordinal, else
+        /// returns <c>-insertionPoint-1</c>, like 
+        /// <see cref="Array.BinarySearch(Array, int, int, object)"/>
         /// </summary>
-        ///  <param name="key"> Key to look up
-        ///  </param>
+        /// <param name="key"> Key to look up</param>
         public virtual int LookupTerm(BytesRef key)
         {
             BytesRef spare = new BytesRef();
@@ -115,8 +114,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns a <seealso cref="TermsEnum"/> over the values.
-        /// The enum supports <seealso cref="TermsEnum#ord()"/> and <seealso cref="TermsEnum#seekExact(long)"/>.
+        /// Returns a <see cref="TermsEnum"/> over the values.
+        /// The enum supports <see cref="TermsEnum.Ord"/> and <see cref="TermsEnum.SeekExact(long)"/>.
         /// </summary>
         public virtual TermsEnum GetTermsEnum()
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedDocValuesTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedDocValuesTermsEnum.cs b/src/Lucene.Net/Index/SortedDocValuesTermsEnum.cs
index d9ff7ef..8ea7576 100644
--- a/src/Lucene.Net/Index/SortedDocValuesTermsEnum.cs
+++ b/src/Lucene.Net/Index/SortedDocValuesTermsEnum.cs
@@ -25,8 +25,8 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// Implements a <seealso cref="TermsEnum"/> wrapping a provided
-    /// <seealso cref="SortedDocValues"/>.
+    /// Implements a <see cref="TermsEnum"/> wrapping a provided
+    /// <see cref="SortedDocValues"/>.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -38,7 +38,7 @@ namespace Lucene.Net.Index
         private readonly BytesRef term = new BytesRef();
 
         /// <summary>
-        /// Creates a new TermsEnum over the provided values </summary>
+        /// Creates a new <see cref="TermsEnum"/> over the provided values </summary>
         public SortedDocValuesTermsEnum(SortedDocValues values)
         {
             this.values = values;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedDocValuesWriter.cs b/src/Lucene.Net/Index/SortedDocValuesWriter.cs
index fd5ae82..b97c2c4 100644
--- a/src/Lucene.Net/Index/SortedDocValuesWriter.cs
+++ b/src/Lucene.Net/Index/SortedDocValuesWriter.cs
@@ -25,8 +25,8 @@ namespace Lucene.Net.Index
      */
 
     /// <summary>
-    /// Buffers up pending byte[] per doc, deref and sorting via
-    ///  int ord, then flushes when segment flushes.
+    /// Buffers up pending <see cref="T:byte[]"/> per doc, deref and sorting via
+    /// int ord, then flushes when segment flushes.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -154,143 +154,5 @@ namespace Lucene.Net.Index
                 yield return ord == -1 ? ord : ordMap[ord];
             }
         }
-
-        /*
-	  private class IterableAnonymousInnerClassHelper : IEnumerable<BytesRef>
-	  {
-		  private readonly SortedDocValuesWriter OuterInstance;
-
-		  private int ValueCount;
-		  private int[] SortedValues;
-
-		  public IterableAnonymousInnerClassHelper(SortedDocValuesWriter outerInstance, int valueCount, int[] sortedValues)
-		  {
-			  this.OuterInstance = outerInstance;
-			  this.ValueCount = valueCount;
-			  this.SortedValues = sortedValues;
-		  }
-
-									// ord -> value
-		  public virtual IEnumerator<BytesRef> GetEnumerator()
-		  {
-			return new ValuesIterator(OuterInstance, SortedValues, ValueCount);
-		  }
-	  }
-
-	  private class IterableAnonymousInnerClassHelper2 : IEnumerable<Number>
-	  {
-		  private readonly SortedDocValuesWriter OuterInstance;
-
-		  private int MaxDoc;
-		  private int[] OrdMap;
-
-		  public IterableAnonymousInnerClassHelper2(SortedDocValuesWriter outerInstance, int maxDoc, int[] ordMap)
-		  {
-			  this.OuterInstance = outerInstance;
-			  this.MaxDoc = maxDoc;
-			  this.OrdMap = ordMap;
-		  }
-
-		  public virtual IEnumerator<Number> GetEnumerator()
-		  {
-			return new OrdsIterator(OuterInstance, OrdMap, MaxDoc);
-		  }
-	  }
-
-	  public override void Abort()
-	  {
-	  }
-
-	  // iterates over the unique values we have in ram
-	  private class ValuesIterator : IEnumerator<BytesRef>
-	  {
-		  private readonly SortedDocValuesWriter OuterInstance;
-
-		internal readonly int[] SortedValues;
-		internal readonly BytesRef Scratch = new BytesRef();
-		internal readonly int ValueCount;
-		internal int OrdUpto;
-
-		internal ValuesIterator(SortedDocValuesWriter outerInstance, int[] sortedValues, int valueCount)
-		{
-			this.OuterInstance = outerInstance;
-		  this.SortedValues = sortedValues;
-		  this.ValueCount = valueCount;
-		}
-
-		public override bool HasNext()
-		{
-		  return OrdUpto < ValueCount;
-		}
-
-		public override BytesRef Next()
-		{
-		  if (!HasNext())
-		  {
-			throw new Exception();
-		  }
-		  OuterInstance.Hash.Get(SortedValues[OrdUpto], Scratch);
-		  OrdUpto++;
-		  return Scratch;
-		}
-
-		public override void Remove()
-		{
-		  throw new System.NotSupportedException();
-		}
-	  }
-
-	  // iterates over the ords for each doc we have in ram
-	  private class OrdsIterator : IEnumerator<Number>
-	  {
-		  internal bool InstanceFieldsInitialized = false;
-
-		  internal virtual void InitializeInstanceFields()
-		  {
-			  Iter = OuterInstance.Pending.Iterator();
-		  }
-
-		  private readonly SortedDocValuesWriter OuterInstance;
-
-		internal AppendingDeltaPackedLongBuffer.Iterator Iter;
-		internal readonly int[] OrdMap;
-		internal readonly int MaxDoc;
-		internal int DocUpto;
-
-		internal OrdsIterator(SortedDocValuesWriter outerInstance, int[] ordMap, int maxDoc)
-		{
-			this.OuterInstance = outerInstance;
-
-			if (!InstanceFieldsInitialized)
-			{
-				InitializeInstanceFields();
-				InstanceFieldsInitialized = true;
-			}
-		  this.OrdMap = ordMap;
-		  this.MaxDoc = maxDoc;
-		  Debug.Assert(outerInstance.Pending.Size() == maxDoc);
-		}
-
-		public override bool HasNext()
-		{
-		  return DocUpto < MaxDoc;
-		}
-
-		public override Number Next()
-		{
-		  if (!HasNext())
-		  {
-			throw new Exception();
-		  }
-		  int ord = (int) Iter.next();
-		  DocUpto++;
-		  return ord == -1 ? ord : OrdMap[ord];
-		}
-
-		public override void Remove()
-		{
-		  throw new System.NotSupportedException();
-		}
-	  }*/
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedSetDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedSetDocValues.cs b/src/Lucene.Net/Index/SortedSetDocValues.cs
index e7844d0..f07d218 100644
--- a/src/Lucene.Net/Index/SortedSetDocValues.cs
+++ b/src/Lucene.Net/Index/SortedSetDocValues.cs
@@ -22,9 +22,9 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// A per-document set of presorted byte[] values.
-    /// <p>
-    /// Per-Document values in a SortedDocValues are deduplicated, dereferenced,
+    /// A per-document set of presorted <see cref="T:byte[]"/> values.
+    /// <para/>
+    /// Per-Document values in a <see cref="SortedDocValues"/> are deduplicated, dereferenced,
     /// and sorted into a dictionary of unique values. A pointer to the
     /// dictionary value (ordinal) can be retrieved for each document. Ordinals
     /// are dense and in increasing sorted order.
@@ -43,15 +43,15 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// When returned by <seealso cref="#nextOrd()"/> it means there are no more
+        /// When returned by <see cref="NextOrd()"/> it means there are no more
         /// ordinals for the document.
         /// </summary>
         public static readonly long NO_MORE_ORDS = -1;
 
         /// <summary>
         /// Returns the next ordinal for the current document (previously
-        /// set by <seealso cref="#setDocument(int)"/>. </summary>
-        /// <returns> next ordinal for the document, or <seealso cref="#NO_MORE_ORDS"/>.
+        /// set by <see cref="SetDocument(int)"/>. </summary>
+        /// <returns> Next ordinal for the document, or <see cref="NO_MORE_ORDS"/>.
         ///         ordinals are dense, start at 0, then increment by 1 for
         ///         the next value in sorted order.  </returns>
         public abstract long NextOrd();
@@ -65,22 +65,21 @@ namespace Lucene.Net.Index
         /// Retrieves the value for the specified ordinal. </summary>
         /// <param name="ord"> ordinal to lookup </param>
         /// <param name="result"> will be populated with the ordinal's value </param>
-        /// <seealso cref= #nextOrd </seealso>
+        /// <seealso cref="NextOrd()"/>
         public abstract void LookupOrd(long ord, BytesRef result);
 
         /// <summary>
         /// Returns the number of unique values. </summary>
-        /// <returns> number of unique values in this SortedDocValues. this is
+        /// <returns> Number of unique values in this <see cref="SortedDocValues"/>. This is
         ///         also equivalent to one plus the maximum ordinal. </returns>
         public abstract long ValueCount { get; }
 
         /// <summary>
-        /// If {@code key} exists, returns its ordinal, else
-        ///  returns {@code -insertionPoint-1}, like {@code
-        ///  Arrays.binarySearch}.
+        /// If <paramref name="key"/> exists, returns its ordinal, else
+        /// returns <c>-insertionPoint-1</c>, like
+        /// <see cref="Array.BinarySearch(Array, int, int, object)"/>.
         /// </summary>
-        ///  <param name="key"> Key to look up
-        ///  </param>
+        /// <param name="key"> Key to look up</param>
         public virtual long LookupTerm(BytesRef key)
         {
             BytesRef spare = new BytesRef();
@@ -111,8 +110,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns a <seealso cref="TermsEnum"/> over the values.
-        /// The enum supports <seealso cref="TermsEnum#ord()"/> and <seealso cref="TermsEnum#seekExact(long)"/>.
+        /// Returns a <see cref="TermsEnum"/> over the values.
+        /// The enum supports <see cref="TermsEnum.Ord"/> and <see cref="TermsEnum.SeekExact(long)"/>.
         /// </summary>
         public virtual TermsEnum GetTermsEnum()
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedSetDocValuesTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedSetDocValuesTermsEnum.cs b/src/Lucene.Net/Index/SortedSetDocValuesTermsEnum.cs
index c2502cb..2ad6e82 100644
--- a/src/Lucene.Net/Index/SortedSetDocValuesTermsEnum.cs
+++ b/src/Lucene.Net/Index/SortedSetDocValuesTermsEnum.cs
@@ -25,8 +25,8 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// Implements a <seealso cref="TermsEnum"/> wrapping a provided
-    /// <seealso cref="SortedSetDocValues"/>.
+    /// Implements a <see cref="TermsEnum"/> wrapping a provided
+    /// <see cref="SortedSetDocValues"/>.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -38,7 +38,7 @@ namespace Lucene.Net.Index
         private readonly BytesRef term = new BytesRef();
 
         /// <summary>
-        /// Creates a new TermsEnum over the provided values </summary>
+        /// Creates a new <see cref="TermsEnum"/> over the provided values </summary>
         public SortedSetDocValuesTermsEnum(SortedSetDocValues values)
         {
             this.values = values;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/SortedSetDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/SortedSetDocValuesWriter.cs b/src/Lucene.Net/Index/SortedSetDocValuesWriter.cs
index c7db93e..a37ebce 100644
--- a/src/Lucene.Net/Index/SortedSetDocValuesWriter.cs
+++ b/src/Lucene.Net/Index/SortedSetDocValuesWriter.cs
@@ -34,8 +34,8 @@ namespace Lucene.Net.Index
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
     /// <summary>
-    /// Buffers up pending byte[]s per doc, deref and sorting via
-    ///  int ord, then flushes when segment flushes.
+    /// Buffers up pending <see cref="T:byte[]"/>s per doc, deref and sorting via
+    /// int ord, then flushes when segment flushes.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -235,230 +235,5 @@ namespace Lucene.Net.Index
                 yield return ord;
             }
         }
-
-        /*
-	  private class IterableAnonymousInnerClassHelper : IEnumerable<BytesRef>
-	  {
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		  private int ValueCount;
-		  private int[] SortedValues;
-
-		  public IterableAnonymousInnerClassHelper(SortedSetDocValuesWriter outerInstance, int valueCount, int[] sortedValues)
-		  {
-			  this.OuterInstance = outerInstance;
-			  this.ValueCount = valueCount;
-			  this.SortedValues = sortedValues;
-		  }
-
-									// ord -> value
-		  public virtual IEnumerator<BytesRef> GetEnumerator()
-		  {
-			return new ValuesIterator(OuterInstance, SortedValues, ValueCount);
-		  }
-	  }
-
-	  private class IterableAnonymousInnerClassHelper2 : IEnumerable<Number>
-	  {
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		  private int MaxDoc;
-
-		  public IterableAnonymousInnerClassHelper2(SortedSetDocValuesWriter outerInstance, int maxDoc)
-		  {
-			  this.OuterInstance = outerInstance;
-			  this.MaxDoc = maxDoc;
-		  }
-
-		  public virtual IEnumerator<Number> GetEnumerator()
-		  {
-			return new OrdCountIterator(OuterInstance, MaxDoc);
-		  }
-	  }
-
-	  private class IterableAnonymousInnerClassHelper3 : IEnumerable<Number>
-	  {
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		  private int MaxCountPerDoc;
-		  private int[] OrdMap;
-
-		  public IterableAnonymousInnerClassHelper3(SortedSetDocValuesWriter outerInstance, int maxCountPerDoc, int[] ordMap)
-		  {
-			  this.OuterInstance = outerInstance;
-			  this.MaxCountPerDoc = maxCountPerDoc;
-			  this.OrdMap = ordMap;
-		  }
-
-		  public virtual IEnumerator<Number> GetEnumerator()
-		  {
-			return new OrdsIterator(OuterInstance, OrdMap, MaxCountPerDoc);
-		  }
-	  }
-
-	  public override void Abort()
-	  {
-	  }
-
-	  // iterates over the unique values we have in ram
-	  private class ValuesIterator : IEnumerator<BytesRef>
-	  {
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		internal readonly int[] SortedValues;
-		internal readonly BytesRef Scratch = new BytesRef();
-		internal readonly int ValueCount;
-		internal int OrdUpto;
-
-		internal ValuesIterator(SortedSetDocValuesWriter outerInstance, int[] sortedValues, int valueCount)
-		{
-			this.OuterInstance = outerInstance;
-		  this.SortedValues = sortedValues;
-		  this.ValueCount = valueCount;
-		}
-
-		public override bool HasNext()
-		{
-		  return OrdUpto < ValueCount;
-		}
-
-		public override BytesRef Next()
-		{
-		  if (!HasNext())
-		  {
-			throw new Exception();
-		  }
-		  OuterInstance.Hash.Get(SortedValues[OrdUpto], Scratch);
-		  OrdUpto++;
-		  return Scratch;
-		}
-
-		public override void Remove()
-		{
-		  throw new System.NotSupportedException();
-		}
-	  }
-
-	  // iterates over the ords for each doc we have in ram
-	  private class OrdsIterator : IEnumerator<Number>
-	  {
-		  internal bool InstanceFieldsInitialized = false;
-
-		  internal virtual void InitializeInstanceFields()
-		  {
-			  Iter = OuterInstance.Pending.Iterator();
-			  Counts = OuterInstance.PendingCounts.Iterator();
-		  }
-
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		internal AppendingPackedLongBuffer.Iterator Iter;
-		internal AppendingDeltaPackedLongBuffer.Iterator Counts;
-		internal readonly int[] OrdMap;
-		internal readonly long NumOrds;
-		internal long OrdUpto;
-
-		internal readonly int[] CurrentDoc;
-		internal int CurrentUpto;
-		internal int CurrentLength;
-
-		internal OrdsIterator(SortedSetDocValuesWriter outerInstance, int[] ordMap, int maxCount)
-		{
-			this.OuterInstance = outerInstance;
-
-			if (!InstanceFieldsInitialized)
-			{
-				InitializeInstanceFields();
-				InstanceFieldsInitialized = true;
-			}
-		  this.CurrentDoc = new int[maxCount];
-		  this.OrdMap = ordMap;
-		  this.NumOrds = outerInstance.Pending.Size();
-		}
-
-		public override bool HasNext()
-		{
-		  return OrdUpto < NumOrds;
-		}
-
-		public override Number Next()
-		{
-		  if (!HasNext())
-		  {
-			throw new Exception();
-		  }
-		  while (CurrentUpto == CurrentLength)
-		  {
-			// refill next doc, and sort remapped ords within the doc.
-			CurrentUpto = 0;
-			CurrentLength = (int) Counts.Next();
-			for (int i = 0; i < CurrentLength; i++)
-			{
-			  CurrentDoc[i] = OrdMap[(int) Iter.Next()];
-			}
-			Array.Sort(CurrentDoc, 0, CurrentLength);
-		  }
-		  int ord = CurrentDoc[CurrentUpto];
-		  CurrentUpto++;
-		  OrdUpto++;
-		  // TODO: make reusable Number
-		  return ord;
-		}
-
-		public override void Remove()
-		{
-		  throw new System.NotSupportedException();
-		}
-	  }
-
-	  private class OrdCountIterator : IEnumerator<Number>
-	  {
-		  internal bool InstanceFieldsInitialized = false;
-
-		  internal virtual void InitializeInstanceFields()
-		  {
-			  Iter = OuterInstance.PendingCounts.Iterator();
-		  }
-
-		  private readonly SortedSetDocValuesWriter OuterInstance;
-
-		internal AppendingDeltaPackedLongBuffer.Iterator Iter;
-		internal readonly int MaxDoc;
-		internal int DocUpto;
-
-		internal OrdCountIterator(SortedSetDocValuesWriter outerInstance, int maxDoc)
-		{
-			this.OuterInstance = outerInstance;
-
-			if (!InstanceFieldsInitialized)
-			{
-				InitializeInstanceFields();
-				InstanceFieldsInitialized = true;
-			}
-		  this.MaxDoc = maxDoc;
-		  Debug.Assert(outerInstance.PendingCounts.Size() == maxDoc);
-		}
-
-		public override bool HasNext()
-		{
-		  return DocUpto < MaxDoc;
-		}
-
-		public override Number Next()
-		{
-		  if (!HasNext())
-		  {
-			throw new Exception();
-		  }
-		  DocUpto++;
-		  // TODO: make reusable Number
-		  return Iter.Next();
-		}
-
-		public override void Remove()
-		{
-		  throw new System.NotSupportedException();
-		}
-	  }*/
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/StandardDirectoryReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/StandardDirectoryReader.cs b/src/Lucene.Net/Index/StandardDirectoryReader.cs
index 2893acf..303d2ca 100644
--- a/src/Lucene.Net/Index/StandardDirectoryReader.cs
+++ b/src/Lucene.Net/Index/StandardDirectoryReader.cs
@@ -38,7 +38,7 @@ namespace Lucene.Net.Index
         private readonly bool applyAllDeletes;
 
         /// <summary>
-        /// called only from static open() methods </summary>
+        /// called only from static <c>Open()</c> methods </summary>
         internal StandardDirectoryReader(Directory directory, AtomicReader[] readers, IndexWriter writer, SegmentInfos sis, int termInfosIndexDivisor, bool applyAllDeletes)
             : base(directory, readers)
         {
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// called from DirectoryReader.open(...) methods </summary>
+        /// called from <c>DirectoryReader.Open(...)</c> methods </summary>
         internal static DirectoryReader Open(Directory directory, IndexCommit commit, int termInfosIndexDivisor)
         {
             return (DirectoryReader)new FindSegmentsFileAnonymousInnerClassHelper(directory, termInfosIndexDivisor).Run(commit);
@@ -171,7 +171,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// this constructor is only used for <seealso cref="#doOpenIfChanged(SegmentInfos)"/> </summary>
+        /// This constructor is only used for <see cref="DoOpenIfChanged(SegmentInfos)"/> </summary>
         private static DirectoryReader Open(Directory directory, SegmentInfos infos, IList<AtomicReader> oldReaders, int termInfosIndexDivisor)
         {
             // we put the old SegmentReaders in a map, that allows us

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/StoredFieldVisitor.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/StoredFieldVisitor.cs b/src/Lucene.Net/Index/StoredFieldVisitor.cs
index 381dc61..16a34ff 100644
--- a/src/Lucene.Net/Index/StoredFieldVisitor.cs
+++ b/src/Lucene.Net/Index/StoredFieldVisitor.cs
@@ -18,24 +18,22 @@ namespace Lucene.Net.Index
      */
 
     /// <summary>
-    /// Expert: provides a low-level means of accessing the stored field
-    /// values in an index.  See {@link IndexReader#document(int,
-    /// StoredFieldVisitor)}.
+    /// Expert: Provides a low-level means of accessing the stored field
+    /// values in an index.  See <see cref="IndexReader.Document(int, StoredFieldVisitor)"/>.
     ///
-    /// <p><b>NOTE</b>: a {@code StoredFieldVisitor} implementation
+    /// <para/><b>NOTE</b>: a <see cref="StoredFieldVisitor"/> implementation
     /// should not try to load or visit other stored documents in
     /// the same reader because the implementation of stored
     /// fields for most codecs is not reeentrant and you will see
     /// strange exceptions as a result.
     ///
-    /// <p>See <seealso cref="DocumentStoredFieldVisitor"/>, which is a
-    /// <code>StoredFieldVisitor</code> that builds the
-    /// <seealso cref="Document"/> containing all stored fields.  this is
-    /// used by <seealso cref="IndexReader#document(int)"/>.
-    ///
+    /// <para/>See <see cref="Documents.DocumentStoredFieldVisitor"/>, which is a
+    /// <see cref="StoredFieldVisitor"/> that builds the
+    /// <see cref="Documents.Document"/> containing all stored fields.  This is
+    /// used by <see cref="IndexReader.Document(int)"/>.
+    /// <para/>
     /// @lucene.experimental
     /// </summary>
-
     public abstract class StoredFieldVisitor
     {
         /// <summary>
@@ -54,31 +52,31 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Process a string field </summary>
+        /// Process a <see cref="string"/> field </summary>
         public virtual void StringField(FieldInfo fieldInfo, string value)
         {
         }
 
         /// <summary>
-        /// Process a int numeric field. </summary>
+        /// Process a <see cref="int"/> numeric field. </summary>
         public virtual void Int32Field(FieldInfo fieldInfo, int value) // LUCENENET specific: Renamed from IntField to Int32Field per .NET conventions
         {
         }
 
         /// <summary>
-        /// Process a long numeric field. </summary>
+        /// Process a <see cref="long"/> numeric field. </summary>
         public virtual void Int64Field(FieldInfo fieldInfo, long value) // LUCENENET specific: Renamed from LongField to Int64Field per .NET conventions
         {
         }
 
         /// <summary>
-        /// Process a float numeric field. </summary>
+        /// Process a <see cref="float"/> numeric field. </summary>
         public virtual void SingleField(FieldInfo fieldInfo, float value) // LUCENENET specific: Renamed from FloatField to SingleField per .NET conventions
         {
         }
 
         /// <summary>
-        /// Process a double numeric field. </summary>
+        /// Process a <see cref="double"/> numeric field. </summary>
         public virtual void DoubleField(FieldInfo fieldInfo, double value)
         {
         }
@@ -86,14 +84,14 @@ namespace Lucene.Net.Index
         /// <summary>
         /// Hook before processing a field.
         /// Before a field is processed, this method is invoked so that
-        /// subclasses can return a <seealso cref="Status"/> representing whether
+        /// subclasses can return a <see cref="Status"/> representing whether
         /// they need that particular field or not, or to stop processing
         /// entirely.
         /// </summary>
         public abstract Status NeedsField(FieldInfo fieldInfo);
 
         /// <summary>
-        /// Enumeration of possible return values for <seealso cref="#needsField"/>.
+        /// Enumeration of possible return values for <see cref="NeedsField(FieldInfo)"/>.
         /// </summary>
         public enum Status
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/StoredFieldsProcessor.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/StoredFieldsProcessor.cs b/src/Lucene.Net/Index/StoredFieldsProcessor.cs
index 6196078..bd16042 100644
--- a/src/Lucene.Net/Index/StoredFieldsProcessor.cs
+++ b/src/Lucene.Net/Index/StoredFieldsProcessor.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Index
     using StoredFieldsWriter = Lucene.Net.Codecs.StoredFieldsWriter;
 
     /// <summary>
-    /// this is a StoredFieldsConsumer that writes stored fields. </summary>
+    /// This is a <see cref="StoredFieldsConsumer"/> that writes stored fields. </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
 #endif

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/TaskMergeScheduler.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/TaskMergeScheduler.cs b/src/Lucene.Net/Index/TaskMergeScheduler.cs
index d87c4dc..3495356 100644
--- a/src/Lucene.Net/Index/TaskMergeScheduler.cs
+++ b/src/Lucene.Net/Index/TaskMergeScheduler.cs
@@ -28,13 +28,13 @@ namespace Lucene.Net.Index
      */
 
     /// <summary>
-    ///  A <seealso cref="MergeScheduler"/> that runs each merge using
-    ///  Tasks on the default TaskScheduler.
+    /// A <see cref="MergeScheduler"/> that runs each merge using
+    /// <see cref="Task"/>s on the default <see cref="TaskScheduler"/>.
     /// 
-    ///  <p>If more than <seealso cref="#GetMaxMergeCount"/> merges are
-    ///  requested then this class will forcefully throttle the
-    ///  incoming threads by pausing until one more more merges
-    ///  complete.</p>
+    /// <para>If more than <see cref="MaxMergeCount"/> merges are
+    /// requested then this class will forcefully throttle the
+    /// incoming threads by pausing until one more more merges
+    /// complete.</para>
     ///  
     /// LUCENENET specific
     /// </summary>
@@ -49,27 +49,27 @@ namespace Lucene.Net.Index
         private readonly ReaderWriterLockSlim _lock = new ReaderWriterLockSlim();
         private readonly ManualResetEventSlim _manualResetEvent = new ManualResetEventSlim();
         /// <summary>
-        /// List of currently active <seealso cref="MergeThread"/>s.</summary>
+        /// List of currently active <see cref="MergeThread"/>s.</summary>
         private readonly IList<MergeThread> _mergeThreads = new List<MergeThread>();
 
         /// <summary>
-        /// How many <seealso cref="MergeThread"/>s have kicked off (this is use
-        ///  to name them).
+        /// How many <see cref="MergeThread"/>s have kicked off (this is use
+        /// to name them).
         /// </summary>
         private int _mergeThreadCount;
 
         /// <summary>
-        /// <seealso cref="Directory"/> that holds the index. </summary>
+        /// <see cref="Directory"/> that holds the index. </summary>
         private Directory _directory;
 
         /// <summary>
-        /// <seealso cref="IndexWriter"/> that owns this instance.
+        /// <seea cref="IndexWriter"/> that owns this instance.
         /// </summary>
         private IndexWriter _writer;
 
         /// <summary>
         /// Sole constructor, with all settings set to default
-        ///  values.
+        /// values.
         /// </summary>
         public TaskMergeScheduler() : base()
         {
@@ -80,14 +80,14 @@ namespace Lucene.Net.Index
         /// <summary>
         /// Sets the maximum number of merge threads and simultaneous merges allowed.
         /// </summary>
-        /// <param name="maxMergeCount"> the max # simultaneous merges that are allowed.
+        /// <param name="maxMergeCount"> The max # simultaneous merges that are allowed.
         ///       If a merge is necessary yet we already have this many
         ///       threads running, the incoming thread (that is calling
         ///       add/updateDocument) will block until a merge thread
         ///       has completed.  Note that we will only run the
-        ///       smallest <code>maxThreadCount</code> merges at a time. </param>
-        /// <param name="maxThreadCount"> the max # simultaneous merge threads that should
-        ///       be running at once.  this must be &lt;= <code>maxMergeCount</code> </param>
+        ///       smallest <paramref name="maxThreadCount"/> merges at a time. </param>
+        /// <param name="maxThreadCount"> The max # simultaneous merge threads that should
+        ///       be running at once.  This must be &lt;= <paramref name="maxMergeCount"/> </param>
         public void SetMaxMergesAndThreads(int maxMergeCount, int maxThreadCount)
         {
             // This is handled by TaskScheduler.Default.MaximumConcurrencyLevel
@@ -97,11 +97,11 @@ namespace Lucene.Net.Index
         /// Max number of merge threads allowed to be running at
         /// once.  When there are more merges then this, we
         /// forcefully pause the larger ones, letting the smaller
-        /// ones run, up until maxMergeCount merges at which point
+        /// ones run, up until <see cref="MaxMergeCount"/> merges at which point
         /// we forcefully pause incoming threads (that presumably
         /// are the ones causing so much merging).
         /// </summary>
-        /// <seealso cref= #setMaxMergesAndThreads(int, int)  </seealso>
+        /// <seealso cref="SetMaxMergesAndThreads(int, int)"/>
         public int MaxThreadCount { get; private set; }
 
         /// <summary>
@@ -134,8 +134,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Called whenever the running merges have changed, to pause & unpause
-        /// threads. this method sorts the merge threads by their merge size in
+        /// Called whenever the running merges have changed, to pause &amp; unpause
+        /// threads. This method sorts the merge threads by their merge size in
         /// descending order and then pauses/unpauses threads from first to last --
         /// that way, smaller merges are guaranteed to run before larger ones.
         /// </summary>
@@ -153,14 +153,14 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns true if verbosing is enabled. this method is usually used in
-        /// conjunction with <seealso cref="#message(String)"/>, like that:
+        /// Returns <c>true</c> if verbosing is enabled. This method is usually used in
+        /// conjunction with <see cref="Message(string)"/>, like that:
         ///
-        /// <pre class="prettyprint">
-        /// if (verbose()) {
-        ///   message(&quot;your message&quot;);
+        /// <code>
+        /// if (Verbose) {
+        ///     Message(&quot;your message&quot;);
         /// }
-        /// </pre>
+        /// </code>
         /// </summary>
         protected bool Verbose
         {
@@ -168,8 +168,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Outputs the given message - this method assumes <seealso cref="#verbose()"/> was
-        /// called and returned true.
+        /// Outputs the given message - this method assumes <see cref="Verbose"/> was
+        /// called and returned <c>true</c>.
         /// </summary>
         protected virtual void Message(string message)
         {
@@ -184,7 +184,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Wait for any running merge threads to finish. 
-        /// This call is not interruptible as used by <seealso cref="#Dispose()"/>.
+        /// This call is not interruptible as used by <see cref="MergeScheduler.Dispose()"/>.
         /// </summary>
         public virtual void Sync()
         {
@@ -217,7 +217,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Returns the number of merge threads that are alive. Note that this number
-        /// is &lt;= <seealso cref="#mergeThreads"/> size.
+        /// is &lt;= <see cref="_mergeThreads"/> size.
         /// </summary>
         private int MergeThreadCount
         {
@@ -347,7 +347,7 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Create and return a new MergeThread </summary>
+        /// Create and return a new <see cref="MergeThread"/> </summary>
         private MergeThread CreateTask(IndexWriter writer, MergePolicy.OneMerge merge)
         {
             var count = Interlocked.Increment(ref _mergeThreadCount);
@@ -358,7 +358,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Called when an exception is hit in a background merge
-        ///  thread
+        /// thread
         /// </summary>
         protected virtual void HandleMergeException(Exception exc)
         {
@@ -424,7 +424,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Runs a merge thread, which may run one or more merges
-        ///  in sequence.
+        /// in sequence.
         /// </summary>
         internal class MergeThread : IDisposable
         {
@@ -491,8 +491,8 @@ namespace Lucene.Net.Index
             }
 
             /// <summary>
-            /// Return the current merge, or null if this {@code
-            ///  MergeThread} is done.
+            /// Return the current merge, or <c>null</c> if this 
+            /// <see cref="MergeThread"/> is done.
             /// </summary>
             public virtual MergePolicy.OneMerge CurrentMerge
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/Term.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/Term.cs b/src/Lucene.Net/Index/Term.cs
index 1cf8dd7..19d5ee2 100644
--- a/src/Lucene.Net/Index/Term.cs
+++ b/src/Lucene.Net/Index/Term.cs
@@ -24,12 +24,12 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    ///  A Term represents a word from text.  this is the unit of search.  It is
-    ///  composed of two elements, the text of the word, as a string, and the name of
-    ///  the field that the text occurred in.
-    ///
-    ///  Note that terms may represent more than words from text fields, but also
-    ///  things like dates, email addresses, urls, etc.
+    /// A <see cref="Term"/> represents a word from text.  This is the unit of search.  It is
+    /// composed of two elements, the text of the word, as a string, and the name of
+    /// the field that the text occurred in.
+    /// <para/>
+    /// Note that terms may represent more than words from text fields, but also
+    /// things like dates, email addresses, urls, etc.
     /// </summary>
 #if FEATURE_SERIALIZABLE
     [Serializable]
@@ -37,14 +37,14 @@ namespace Lucene.Net.Index
     public sealed class Term : IComparable<Term>, IEquatable<Term> // LUCENENET specific - class implements IEquatable<T>
     {
         /// <summary>
-        /// Constructs a Term with the given field and bytes.
-        /// <p>Note that a null field or null bytes value results in undefined
+        /// Constructs a <see cref="Term"/> with the given field and bytes.
+        /// <para/>Note that a null field or null bytes value results in undefined
         /// behavior for most Lucene APIs that accept a Term parameter.
         ///
-        /// <p>WARNING: the provided BytesRef is not copied, but used directly.
+        /// <para/>WARNING: the provided <see cref="BytesRef"/> is not copied, but used directly.
         /// Therefore the bytes should not be modified after construction, for
-        /// example, you should clone a copy by <seealso cref="BytesRef#deepCopyOf"/>
-        /// rather than pass reused bytes from a TermsEnum.
+        /// example, you should clone a copy by <see cref="BytesRef.DeepCopyOf(BytesRef)"/>
+        /// rather than pass reused bytes from a <see cref="TermsEnum"/>.
         /// </summary>
         public Term(string fld, BytesRef bytes)
         {
@@ -53,9 +53,9 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Constructs a Term with the given field and text.
-        /// <p>Note that a null field or null text value results in undefined
-        /// behavior for most Lucene APIs that accept a Term parameter.
+        /// Constructs a <see cref="Term"/> with the given field and text.
+        /// <para/>Note that a <c>null</c> field or null text value results in undefined
+        /// behavior for most Lucene APIs that accept a <see cref="Term"/> parameter.
         /// </summary>
         public Term(string fld, string text)
             : this(fld, new BytesRef(text))
@@ -63,8 +63,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Constructs a Term with the given field and empty text.
-        /// this serves two purposes: 1) reuse of a Term with the same field.
+        /// Constructs a <see cref="Term"/> with the given field and empty text.
+        /// this serves two purposes: 1) reuse of a <see cref="Term"/> with the same field.
         /// 2) pattern for a query.
         /// </summary>
         /// <param name="fld"> field's name </param>
@@ -74,15 +74,15 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns the field of this term.   The field indicates
-        ///  the part of a document which this term came from.
+        /// Returns the field of this term.  The field indicates
+        /// the part of a document which this term came from.
         /// </summary>
         public string Field { get; internal set; }
 
         /// <summary>
         /// Returns the text of this term.  In the case of words, this is simply the
-        ///  text of the word.  In the case of dates and other types, this is an
-        ///  encoding of the object as a string.
+        /// text of the word.  In the case of dates and other types, this is an
+        /// encoding of the object as a string.
         /// </summary>
         public string Text()
         {
@@ -129,10 +129,10 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Compares two terms, returning a negative integer if this
-        ///  term belongs before the argument, zero if this term is equal to the
-        ///  argument, and a positive integer if this term belongs after the argument.
-        ///
-        ///  The ordering of terms is first by field, then by text.
+        /// term belongs before the argument, zero if this term is equal to the
+        /// argument, and a positive integer if this term belongs after the argument.
+        /// <para/>
+        /// The ordering of terms is first by field, then by text.
         /// </summary>
         public int CompareTo(Term other)
         {
@@ -148,8 +148,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Resets the field and text of a Term.
-        /// <p>WARNING: the provided BytesRef is not copied, but used directly.
+        /// Resets the field and text of a <see cref="Term"/>.
+        /// <para/>WARNING: the provided <see cref="BytesRef"/> is not copied, but used directly.
         /// Therefore the bytes should not be modified after construction, for
         /// example, you should clone a copy rather than pass reused bytes from
         /// a TermsEnum.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/TermContext.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/TermContext.cs b/src/Lucene.Net/Index/TermContext.cs
index 945d928..b389c60 100644
--- a/src/Lucene.Net/Index/TermContext.cs
+++ b/src/Lucene.Net/Index/TermContext.cs
@@ -24,12 +24,12 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
 
     /// <summary>
-    /// Maintains a <seealso cref="IndexReader"/> <seealso cref="TermState"/> view over
-    /// <seealso cref="IndexReader"/> instances containing a single term. The
-    /// <seealso cref="TermContext"/> doesn't track if the given <seealso cref="TermState"/>
-    /// objects are valid, neither if the <seealso cref="TermState"/> instances refer to the
+    /// Maintains a <see cref="IndexReader"/> <see cref="TermState"/> view over
+    /// <see cref="IndexReader"/> instances containing a single term. The
+    /// <see cref="TermContext"/> doesn't track if the given <see cref="TermState"/>
+    /// objects are valid, neither if the <see cref="TermState"/> instances refer to the
     /// same terms in the associated readers.
-    ///
+    /// <para/>
     /// @lucene.experimental
     /// </summary>
 #if FEATURE_SERIALIZABLE
@@ -38,11 +38,11 @@ namespace Lucene.Net.Index
     public sealed class TermContext
     {
         /// <summary>
-        /// Holds the <seealso cref="IndexReaderContext"/> of the top-level
-        ///  <seealso cref="IndexReader"/>, used internally only for
-        ///  asserting.
-        ///
-        ///  @lucene.internal
+        /// Holds the <see cref="IndexReaderContext"/> of the top-level
+        /// <see cref="IndexReader"/>, used internally only for
+        /// asserting.
+        /// <para/>
+        /// @lucene.internal
         /// </summary>
         public IndexReaderContext TopReaderContext { get; private set; }
 
@@ -53,7 +53,7 @@ namespace Lucene.Net.Index
         //public static boolean DEBUG = BlockTreeTermsWriter.DEBUG;
 
         /// <summary>
-        /// Creates an empty <seealso cref="TermContext"/> from a <seealso cref="IndexReaderContext"/>
+        /// Creates an empty <see cref="TermContext"/> from a <see cref="IndexReaderContext"/>
         /// </summary>
         public TermContext(IndexReaderContext context)
         {
@@ -73,8 +73,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Creates a <seealso cref="TermContext"/> with an initial <seealso cref="TermState"/>,
-        /// <seealso cref="IndexReader"/> pair.
+        /// Creates a <see cref="TermContext"/> with an initial <see cref="TermState"/>,
+        /// <see cref="IndexReader"/> pair.
         /// </summary>
         public TermContext(IndexReaderContext context, TermState state, int ord, int docFreq, long totalTermFreq)
             : this(context)
@@ -83,11 +83,11 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Creates a <seealso cref="TermContext"/> from a top-level <seealso cref="IndexReaderContext"/> and the
-        /// given <seealso cref="Term"/>. this method will lookup the given term in all context's leaf readers
-        /// and register each of the readers containing the term in the returned <seealso cref="TermContext"/>
+        /// Creates a <see cref="TermContext"/> from a top-level <see cref="IndexReaderContext"/> and the
+        /// given <see cref="Term"/>. this method will lookup the given term in all context's leaf readers
+        /// and register each of the readers containing the term in the returned <see cref="TermContext"/>
         /// using the leaf reader's ordinal.
-        /// <p>
+        /// <para/>
         /// Note: the given context must be a top-level context.
         /// </summary>
         public static TermContext Build(IndexReaderContext context, Term term)
@@ -120,8 +120,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Clears the <seealso cref="TermContext"/> internal state and removes all
-        /// registered <seealso cref="TermState"/>s
+        /// Clears the <see cref="TermContext"/> internal state and removes all
+        /// registered <see cref="TermState"/>s
         /// </summary>
         public void Clear()
         {
@@ -130,8 +130,8 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Registers and associates a <seealso cref="TermState"/> with an leaf ordinal. The leaf ordinal
-        /// should be derived from a <seealso cref="IndexReaderContext"/>'s leaf ord.
+        /// Registers and associates a <see cref="TermState"/> with an leaf ordinal. The leaf ordinal
+        /// should be derived from a <see cref="IndexReaderContext"/>'s leaf ord.
         /// </summary>
         public void Register(TermState state, int ord, int docFreq, long totalTermFreq)
         {
@@ -151,13 +151,13 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Returns the <seealso cref="TermState"/> for an leaf ordinal or <code>null</code> if no
-        /// <seealso cref="TermState"/> for the ordinal was registered.
+        /// Returns the <see cref="TermState"/> for an leaf ordinal or <c>null</c> if no
+        /// <see cref="TermState"/> for the ordinal was registered.
         /// </summary>
         /// <param name="ord">
-        ///          the readers leaf ordinal to get the <seealso cref="TermState"/> for. </param>
-        /// <returns> the <seealso cref="TermState"/> for the given readers ord or <code>null</code> if no
-        ///         <seealso cref="TermState"/> for the reader was registered </returns>
+        ///          The readers leaf ordinal to get the <see cref="TermState"/> for. </param>
+        /// <returns> The <see cref="TermState"/> for the given readers ord or <c>null</c> if no
+        ///         <see cref="TermState"/> for the reader was registered </returns>
         public TermState Get(int ord)
         {
             Debug.Assert(ord >= 0 && ord < states.Length);
@@ -165,10 +165,10 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        ///  Returns the accumulated term frequency of all <seealso cref="TermState"/>
-        ///         instances passed to <seealso cref="#register(TermState, int, int, long)"/>. </summary>
-        /// <returns> the accumulated term frequency of all <seealso cref="TermState"/>
-        ///         instances passed to <seealso cref="#register(TermState, int, int, long)"/>. </returns>
+        ///  Returns the accumulated term frequency of all <see cref="TermState"/>
+        ///         instances passed to <see cref="Register(TermState, int, int, long)"/>. </summary>
+        /// <returns> the accumulated term frequency of all <see cref="TermState"/>
+        ///         instances passed to <see cref="Register(TermState, int, int, long)"/>. </returns>
         public long TotalTermFreq
         {
             get { return totalTermFreq; }
@@ -176,11 +176,12 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// expert: only available for queries that want to lie about docfreq
+        /// <para/>
         /// @lucene.internal
         /// </summary>
         public int DocFreq
         {
-            set
+            internal set
             {
                 this.docFreq = value;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/TermState.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/TermState.cs b/src/Lucene.Net/Index/TermState.cs
index c5dd839..5ecff88 100644
--- a/src/Lucene.Net/Index/TermState.cs
+++ b/src/Lucene.Net/Index/TermState.cs
@@ -21,11 +21,12 @@ namespace Lucene.Net.Index
 
     /// <summary>
     /// Encapsulates all required internal state to position the associated
-    /// <seealso cref="TermsEnum"/> without re-seeking.
+    /// <see cref="TermsEnum"/> without re-seeking.
+    /// <para/>
+    /// @lucene.experimental
     /// </summary>
-    /// <seealso cref= TermsEnum#seekExact(Lucene.Net.Util.BytesRef, TermState) </seealso>
-    /// <seealso cref= TermsEnum#termState()
-    /// @lucene.experimental </seealso>
+    /// <seealso cref="TermsEnum.SeekExact(Lucene.Net.Util.BytesRef, TermState)"/>
+    /// <seealso cref="TermsEnum.GetTermState()"/>
 #if FEATURE_SERIALIZABLE
     [Serializable]
 #endif
@@ -33,17 +34,17 @@ namespace Lucene.Net.Index
     {
         /// <summary>
         /// Sole constructor. (For invocation by subclass
-        ///  constructors, typically implicit.)
+        /// constructors, typically implicit.)
         /// </summary>
         protected TermState()
         {
         }
 
         /// <summary>
-        /// Copies the content of the given <seealso cref="TermState"/> to this instance
+        /// Copies the content of the given <see cref="TermState"/> to this instance
         /// </summary>
         /// <param name="other">
-        ///          the TermState to copy </param>
+        ///          the <see cref="TermState"/> to copy </param>
         public abstract void CopyFrom(TermState other);
 
         public virtual object Clone()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/TermVectorsConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/TermVectorsConsumer.cs b/src/Lucene.Net/Index/TermVectorsConsumer.cs
index 04ba05d..f1c8019 100644
--- a/src/Lucene.Net/Index/TermVectorsConsumer.cs
+++ b/src/Lucene.Net/Index/TermVectorsConsumer.cs
@@ -88,7 +88,7 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Fills in no-term-vectors for all docs we haven't seen
-        ///  since the last doc that had term vectors.
+        /// since the last doc that had term vectors.
         /// </summary>
         internal void Fill(int docID)
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/646db0ce/src/Lucene.Net/Index/TermVectorsConsumerPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net/Index/TermVectorsConsumerPerField.cs b/src/Lucene.Net/Index/TermVectorsConsumerPerField.cs
index f24e457..16dacea 100644
--- a/src/Lucene.Net/Index/TermVectorsConsumerPerField.cs
+++ b/src/Lucene.Net/Index/TermVectorsConsumerPerField.cs
@@ -156,9 +156,10 @@ namespace Lucene.Net.Index
 
         /// <summary>
         /// Called once per field per document if term vectors
-        ///  are enabled, to write the vectors to
-        ///  RAMOutputStream, which is then quickly flushed to
-        ///  the real term vectors files in the Directory. 	  /// </summary>
+        /// are enabled, to write the vectors to
+        /// RAMOutputStream, which is then quickly flushed to
+        /// the real term vectors files in the Directory. 	  
+        /// </summary>
         internal override void Finish()
         {
             if (!doVectors || termsHashPerField.bytesHash.Count == 0)